2025.10.23 23:27:48.507739 [ 411 ] {} Context: ThreadFuzzer is enabled. Application will run slowly and unstable. 2025.10.23 23:27:48.507870 [ 411 ] {} Context: Server was built with memory sanitizer. It will work slowly. 2025.10.23 23:27:48.535485 [ 411 ] {} Context: Delay accounting is not enabled, OSIOWaitMicroseconds will not be gathered. You can enable it using `echo 1 > /proc/sys/kernel/task_delayacct` or by using sysctl. 2025.10.23 23:27:48.537009 [ 411 ] {} Context: The setting 'allow_remote_fs_zero_copy_replication' is enabled for MergeTree tables. But the feature of 'zero-copy replication' is under development and is not ready for production. The usage of this feature can lead to data corruption and loss. The setting should be disabled in production. 2025.10.23 23:28:21.218867 [ 411 ] {} KeeperLogStore: No logs exists in /var/lib/clickhouse/coordination/logs. It's Ok if it's the first run of clickhouse-keeper. 2025.10.23 23:28:21.220696 [ 411 ] {} KeeperLogStore: Removing all changelogs 2025.10.23 23:28:21.222544 [ 411 ] {} KeeperServer: Got 1000000000000000 value for setting 'reserved_log_items' which is bigger than int32_t max value, lowering value to 2147483647. 2025.10.23 23:28:21.233276 [ 411 ] {} RaftInstance: invalid election timeout lower bound detected, adjusted to 0 2025.10.23 23:28:21.233366 [ 411 ] {} RaftInstance: invalid election timeout upper bound detected, adjusted to 0 2025.10.23 23:28:21.284777 [ 1161 ] {} RaftInstance: Election timeout, initiate leader election 2025.10.23 23:28:21.396155 [ 411 ] {} Access(local_directory): File /var/lib/clickhouse/access/users.list doesn't exist 2025.10.23 23:28:21.396233 [ 411 ] {} Access(local_directory): Recovering lists in directory /var/lib/clickhouse/access/ 2025.10.23 23:28:22.376979 [ 411 ] {} Context: Table system.session_log is enabled. It's unreliable and may contain garbage. Do not use it for any kind of security monitoring. 2025.10.23 23:28:34.600632 [ 415 ] {8eebf4bb-bcc4-4f9a-a3df-5d1e2c262646} InterpreterCreateQuery: ATTACH TABLE query with full table definition is not recommended: use either ATTACH TABLE hits_v1; to attach existing table or CREATE TABLE hits_v1 ; to create new table or ATTACH TABLE hits_v1 FROM '/path/to/data/'
; to create new table and attach data. 2025.10.23 23:28:45.776702 [ 415 ] {539886a5-597d-4401-83da-a70c5ba467af} InterpreterCreateQuery: ATTACH TABLE query with full table definition is not recommended: use either ATTACH TABLE visits_v1; to attach existing table or CREATE TABLE visits_v1
; to create new table or ATTACH TABLE visits_v1 FROM '/path/to/data/'
; to create new table and attach data. 2025.10.23 23:28:57.263061 [ 1176 ] {} RaftInstance: failed to accept a rpc connection due to error 125, Operation canceled 2025.10.23 23:28:59.821181 [ 1415 ] {} Context: ThreadFuzzer is enabled. Application will run slowly and unstable. 2025.10.23 23:28:59.821296 [ 1415 ] {} Context: Server was built with memory sanitizer. It will work slowly. 2025.10.23 23:28:59.846093 [ 1415 ] {} Context: Delay accounting is not enabled, OSIOWaitMicroseconds will not be gathered. You can enable it using `echo 1 > /proc/sys/kernel/task_delayacct` or by using sysctl. 2025.10.23 23:28:59.847371 [ 1415 ] {} Context: The setting 'allow_remote_fs_zero_copy_replication' is enabled for MergeTree tables. But the feature of 'zero-copy replication' is under development and is not ready for production. The usage of this feature can lead to data corruption and loss. The setting should be disabled in production. 2025.10.23 23:29:27.459669 [ 1415 ] {} KeeperServer: Got 1000000000000000 value for setting 'reserved_log_items' which is bigger than int32_t max value, lowering value to 2147483647. 2025.10.23 23:29:27.472246 [ 1415 ] {} RaftInstance: invalid election timeout lower bound detected, adjusted to 0 2025.10.23 23:29:27.472378 [ 1415 ] {} RaftInstance: invalid election timeout upper bound detected, adjusted to 0 2025.10.23 23:29:27.524127 [ 2138 ] {} RaftInstance: Election timeout, initiate leader election 2025.10.23 23:29:31.532025 [ 1415 ] {} Context: Table system.session_log is enabled. It's unreliable and may contain garbage. Do not use it for any kind of security monitoring. 2025.10.23 23:30:03.849366 [ 2172 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {c84fffe3-f7b9-426e-917b-60cee886efa2::202510_1_6_1}: Code: 241. DB::Exception: Memory tracker (for thread): fault injected (at specific point). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000002009b98d 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x000000002009675f 5. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:129: CurrentMemoryTracker::injectFault() @ 0x000000001ff7d1df 6. ./build_docker/./src/Common/ThreadFuzzer.cpp:270: DB::ThreadFuzzer::maybeInjectMemoryLimitException() @ 0x000000002011909f 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:151: DB::MergePlainMergeTreeTask::finish() @ 0x000000003a3c7732 8. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3c4534 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 17. ? @ 0x00007f0a53cf8ac3 18. ? @ 0x00007f0a53d8a850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:12.639402 [ 2161 ] {} CgroupsMemoryUsageObserver: Exceeded hard memory limit (14.54 GiB) 2025.10.23 23:30:12.639614 [ 2161 ] {} CgroupsMemoryUsageObserver: Exceeded soft memory limit (13.77 GiB) 2025.10.23 23:30:16.865575 [ 1419 ] {89356b0f-c3a3-444a-a959-f29be4e0eb91} executeQuery: Code: 241. DB::Exception: Memory limit (total) exceeded: would use 15.33 GiB (attempt to allocate chunk of 1049600 bytes), maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker.: (while reading column ParsedParams.ValueDouble): (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 0 with max_rows_to_read = 8192): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:46174) (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000002009bbd0 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099e92 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099272 6. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099272 7. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099272 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7ca1d 9. ./build_docker/./src/Common/Allocator.cpp:237: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001ff781e5 10. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x00000000083875f3 11. ./src/Common/PODArray.h:208: 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 @ 0x0000000032668352 12. ./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) @ 0x0000000039d06782 13. ./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>>&) @ 0x0000000039d04ac6 14. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039cb3032 15. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039cd6816 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000039ccef53 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000039d4a566 18. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000003bf80734 19. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:206: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d3c6b0 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf89b85 21. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 22. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 26. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 28. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 30. ? @ 0x00007f0a53cf8ac3 31. ? @ 0x00007f0a53d8a850 2025.10.23 23:30:20.951031 [ 1419 ] {89356b0f-c3a3-444a-a959-f29be4e0eb91} TCPHandler: Code: 241. DB::Exception: Memory limit (total) exceeded: would use 15.33 GiB (attempt to allocate chunk of 1049600 bytes), maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker.: (while reading column ParsedParams.ValueDouble): (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 0 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000002009bbd0 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099e92 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099272 6. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099272 7. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099272 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7ca1d 9. ./build_docker/./src/Common/Allocator.cpp:237: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001ff781e5 10. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x00000000083875f3 11. ./src/Common/PODArray.h:208: 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 @ 0x0000000032668352 12. ./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) @ 0x0000000039d06782 13. ./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>>&) @ 0x0000000039d04ac6 14. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039cb3032 15. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039cd6816 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000039ccef53 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000039d4a566 18. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000003bf80734 19. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:206: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d3c6b0 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf89b85 21. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 22. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 26. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 28. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 30. ? @ 0x00007f0a53cf8ac3 31. ? @ 0x00007f0a53d8a850 2025.10.23 23:30:46.017449 [ 1419 ] {a4b5adbf-a41d-496a-a440-83c5683ed868} executeQuery: Code: 241. DB::Exception: Memory limit (total) exceeded: would use 15.39 GiB (attempt to allocate chunk of 1147008 bytes), maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker.: (while reading column ParsedParams.Key3): (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 0 with max_rows_to_read = 8192): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:39740) (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000002009bbd0 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099e92 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099272 6. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099272 7. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099272 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7ca1d 9. ./build_docker/./src/Common/Allocator.cpp:237: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001ff781e5 10. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x00000000083875f3 11. ./src/Common/PODArray.h:208: 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 @ 0x0000000032668352 12. ./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) @ 0x0000000039d06782 13. ./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>>&) @ 0x0000000039d04ac6 14. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039cb3032 15. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039cd6816 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000039ccef53 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000039d4a566 18. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000003bf80734 19. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:206: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d3c6b0 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf89b85 21. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 22. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 26. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 28. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 30. ? @ 0x00007f0a53cf8ac3 31. ? @ 0x00007f0a53d8a850 2025.10.23 23:30:48.884101 [ 1419 ] {a4b5adbf-a41d-496a-a440-83c5683ed868} TCPHandler: Code: 241. DB::Exception: Memory limit (total) exceeded: would use 15.39 GiB (attempt to allocate chunk of 1147008 bytes), maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker.: (while reading column ParsedParams.Key3): (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 0 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000002009bbd0 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099e92 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099272 6. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099272 7. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099272 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7ca1d 9. ./build_docker/./src/Common/Allocator.cpp:237: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001ff781e5 10. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x00000000083875f3 11. ./src/Common/PODArray.h:208: 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 @ 0x0000000032668352 12. ./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) @ 0x0000000039d06782 13. ./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>>&) @ 0x0000000039d04ac6 14. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039cb3032 15. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039cd6816 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000039ccef53 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000039d4a566 18. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000003bf80734 19. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:206: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d3c6b0 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf89b85 21. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 22. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 26. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 28. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 30. ? @ 0x00007f0a53cf8ac3 31. ? @ 0x00007f0a53d8a850 2025.10.23 23:31:12.645503 [ 2161 ] {} CgroupsMemoryUsageObserver: Exceeded hard memory limit (14.54 GiB) 2025.10.23 23:31:12.645630 [ 2161 ] {} CgroupsMemoryUsageObserver: Exceeded soft memory limit (13.77 GiB) 2025.10.23 23:31:36.489008 [ 1419 ] {60568026-00fb-424f-997b-fb1e4dbe233d} executeQuery: Code: 241. DB::Exception: Memory limit (total) exceeded: would use 15.61 GiB (attempt to allocate chunk of 1073120 bytes), maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker.: (while reading column OpenstatSourceIDHash): (while reading from part store/513/5131f834-711f-4168-98a5-968b691a104b/201403_1_8_2/ in table datasets.visits_v1 (5131f834-711f-4168-98a5-968b691a104b) located on disk __tmp_internal_262634248876485800814430204900764312493 of type web, from mark 0 with max_rows_to_read = 6682): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37716) (in query: INSERT INTO test.visits SELECT * FROM datasets.visits_v1 SETTINGS enable_filesystem_cache_on_write_operations=0, max_insert_threads=16), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000002009bbd0 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099e92 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099272 6. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099272 7. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099272 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7ca1d 9. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ff775a4 10. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x000000000838765c 11. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:0: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000032795b3f 12. ./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 @ 0x0000000032642210 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) @ 0x0000000039d06782 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>>&) @ 0x0000000039d04ac6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039cb3032 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039cd6816 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000039ccef53 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000039d4a566 19. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000003bf80734 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:206: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d3c6b0 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf89b85 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 31. ? @ 0x00007f0a53cf8ac3 2025.10.23 23:31:39.830089 [ 1419 ] {60568026-00fb-424f-997b-fb1e4dbe233d} TCPHandler: Code: 241. DB::Exception: Memory limit (total) exceeded: would use 15.61 GiB (attempt to allocate chunk of 1073120 bytes), maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker.: (while reading column OpenstatSourceIDHash): (while reading from part store/513/5131f834-711f-4168-98a5-968b691a104b/201403_1_8_2/ in table datasets.visits_v1 (5131f834-711f-4168-98a5-968b691a104b) located on disk __tmp_internal_262634248876485800814430204900764312493 of type web, from mark 0 with max_rows_to_read = 6682): 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000002009bbd0 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099e92 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099272 6. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099272 7. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099272 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7ca1d 9. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ff775a4 10. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x000000000838765c 11. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:0: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000032795b3f 12. ./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 @ 0x0000000032642210 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) @ 0x0000000039d06782 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>>&) @ 0x0000000039d04ac6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039cb3032 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039cd6816 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000039ccef53 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000039d4a566 19. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000003bf80734 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:206: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d3c6b0 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf89b85 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 31. ? @ 0x00007f0a53cf8ac3 2025.10.23 23:31:50.534261 [ 2153 ] {} RaftInstance: failed to accept a rpc connection due to error 125, Operation canceled 2025.10.23 23:31:53.560262 [ 2898 ] {} Context: ThreadFuzzer is enabled. Application will run slowly and unstable. 2025.10.23 23:31:53.560409 [ 2898 ] {} Context: Server was built with memory sanitizer. It will work slowly. 2025.10.23 23:31:53.589348 [ 2898 ] {} Context: Server logging level is set to 'test' and performance is degraded. This cannot be used in production. 2025.10.23 23:31:53.593618 [ 2898 ] {} Context: Delay accounting is not enabled, OSIOWaitMicroseconds will not be gathered. You can enable it using `echo 1 > /proc/sys/kernel/task_delayacct` or by using sysctl. 2025.10.23 23:31:53.595155 [ 2898 ] {} Context: The setting 'allow_remote_fs_zero_copy_replication' is enabled for MergeTree tables. But the feature of 'zero-copy replication' is under development and is not ready for production. The usage of this feature can lead to data corruption and loss. The setting should be disabled in production. 2025.10.23 23:32:20.930403 [ 2898 ] {} KeeperServer: Got 1000000000000000 value for setting 'reserved_log_items' which is bigger than int32_t max value, lowering value to 2147483647. 2025.10.23 23:32:21.086899 [ 2898 ] {} RaftInstance: invalid election timeout lower bound detected, adjusted to 0 2025.10.23 23:32:21.087013 [ 2898 ] {} RaftInstance: invalid election timeout upper bound detected, adjusted to 0 2025.10.23 23:32:21.138790 [ 3618 ] {} RaftInstance: Election timeout, initiate leader election 2025.10.23 23:32:26.282695 [ 2898 ] {} Context: Table system.session_log is enabled. It's unreliable and may contain garbage. Do not use it for any kind of security monitoring. 2025.10.23 23:32:29.434448 [ 2902 ] {d7d8660f-9922-42b0-a8f3-3646d02c7d2c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59688) (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:32:29.435886 [ 2902 ] {d7d8660f-9922-42b0-a8f3-3646d02c7d2c} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:32:45.929142 [ 2904 ] {01dc8a21-ee00-4af5-82cd-38156412a31b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=8, jobs=8). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:54046) (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6377 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 2025.10.23 23:32:45.933623 [ 2904 ] {01dc8a21-ee00-4af5-82cd-38156412a31b} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=8, jobs=8). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6377 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:47.611282 [ 3903 ] {f13b168b-bb57-4783-98bb-55aa8172179f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, jobs=14). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:52500) (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6377 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 2025.10.23 23:32:47.614018 [ 3903 ] {f13b168b-bb57-4783-98bb-55aa8172179f} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, jobs=14). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6377 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:47.899227 [ 3894 ] {e23c1fcb-15e6-4b92-b934-b54645089b6f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:52216) (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:32:47.901973 [ 3894 ] {e23c1fcb-15e6-4b92-b934-b54645089b6f} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:49.041310 [ 2904 ] {8d341260-8802-456a-ac92-acf0f89b3daa} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=3, jobs=3). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:52524) (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:32:49.043887 [ 2904 ] {8d341260-8802-456a-ac92-acf0f89b3daa} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=3, jobs=3). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:49.096275 [ 3713 ] {} void DB::AsyncLoader::worker(Pool &): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=721, jobs=705). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000003398a0f9 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::DDLWorker::startup() @ 0x000000003393959a 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&) @ 0x0000000032a9d83f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000207110e6 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000020712b00 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:49.395872 [ 2902 ] {f206f0f1-e7a7-4c7d-bd89-242f693d87d5} DeflateQplJobHWPool: Initialization of hardware-assisted DeflateQpl codec failed, falling back to software DeflateQpl codec. Failed to get available workqueue size -> total_wq_size: 0, QPL Version: 1.6.0. 2025.10.23 23:32:49.587830 [ 3894 ] {9a35509b-45a8-4207-bae3-929f1078ac62} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48442) (comment: 01518_nullable_aggregate_states1.sql) (in query: select countMerge(cnts), countMerge(cntsa), maxMerge(maxs), minMerge(mins), avgMerge(avgs), sumMerge(sums), anyMerge(anys) from ( select countState() cnts, countState(a) cntsa, maxState(a) maxs, minState(a) mins, avgState(a) avgs, sumState(a) sums, anyState(a) anys from (select cast(Null,'Nullable(Float64)') 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:32:49.776861 [ 3894 ] {9a35509b-45a8-4207-bae3-929f1078ac62} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:32:49.781011 [ 3895 ] {467dd367-50af-4420-98fc-59c800bc3cac} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=15, jobs=15). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:52566) (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6377 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 2025.10.23 23:32:49.783584 [ 3895 ] {467dd367-50af-4420-98fc-59c800bc3cac} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=15, jobs=15). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6377 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:50.474440 [ 2904 ] {3ff0b11d-a3bf-4fb8-8d2b-eadc271f5f18} DatabaseReplicated (test_3nlivyhn): It's not recommended to explicitly specify zookeeper_path and replica_name in ReplicatedMergeTree arguments 2025.10.23 23:32:50.756872 [ 3903 ] {07eb68fd-70c2-4280-b562-8a11dd9f16dc} executeQuery: Code: 722. DB::Exception: Waited job failed: Code: 695. DB::Exception: Load job 'startup Replicated database test_5' failed: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=721, jobs=705). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000003398a0f9 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::DDLWorker::startup() @ 0x000000003393959a 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&) @ 0x0000000032a9d83f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000207110e6 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000020712b00 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)). (ASYNC_LOAD_FAILED) (version 24.8.14.10542.altinitytest (altinity build)). (ASYNC_LOAD_WAIT_FAILED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:52514) (in query: CREATE DATABASE IF NOT EXISTS test_5 ENGINE=Replicated('/test/db/test_5', '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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Common/AsyncLoader.cpp:444: DB::AsyncLoader::wait(std::shared_ptr const&, bool) @ 0x0000000020706a5b 5. ./src/Common/AsyncLoader.h:547: DB::waitLoad(unsigned long, std::vector, std::allocator>> const&, bool) @ 0x000000002065a61b 6. ./contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000348954c8 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 10. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 11. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:32:50.759299 [ 3903 ] {07eb68fd-70c2-4280-b562-8a11dd9f16dc} DynamicQueryHandler: Code: 722. DB::Exception: Waited job failed: Code: 695. DB::Exception: Load job 'startup Replicated database test_5' failed: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=721, jobs=705). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000003398a0f9 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::DDLWorker::startup() @ 0x000000003393959a 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&) @ 0x0000000032a9d83f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000207110e6 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000020712b00 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)). (ASYNC_LOAD_FAILED) (version 24.8.14.10542.altinitytest (altinity build)). (ASYNC_LOAD_WAIT_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Common/AsyncLoader.cpp:444: DB::AsyncLoader::wait(std::shared_ptr const&, bool) @ 0x0000000020706a5b 5. ./src/Common/AsyncLoader.h:547: DB::waitLoad(unsigned long, std::vector, std::allocator>> const&, bool) @ 0x000000002065a61b 6. ./contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000348954c8 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 10. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 11. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:51.076926 [ 3903 ] {d1394fce-ce95-4dae-a469-b9a3a91be3aa} 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.10542.altinitytest (altinity build)) (from [::1]:52930) (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6377 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 2025.10.23 23:32:51.079071 [ 3903 ] {d1394fce-ce95-4dae-a469-b9a3a91be3aa} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=12, jobs=12). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6377 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:51.482663 [ 2904 ] {3ff0b11d-a3bf-4fb8-8d2b-eadc271f5f18} executeQuery: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48448) (comment: 00516_deduplication_after_drop_partition_zookeeper.sql) (in query: CREATE TABLE deduplication_by_partition (`d` Date, `x` UInt32) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/test_00516/deduplication_by_partition', 'r1') PARTITION BY toYYYYMM(d) ORDER BY x SETTINGS index_granularity = 56845, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 11, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 247373746, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 2202204, merge_max_block_size = 7370, old_parts_lifetime = 92., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 11, min_merge_bytes_to_use_direct_io = 10493188013, index_granularity_bytes = 21777800, concurrent_part_removal_threshold = 2, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 57210, primary_key_compress_block_size = 24749), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000032a4a38c 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000032a4fcff 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a51799 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfab2 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:32:51.484891 [ 2904 ] {3ff0b11d-a3bf-4fb8-8d2b-eadc271f5f18} TCPHandler: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000032a4a38c 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000032a4fcff 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a51799 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfab2 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:32:51.583580 [ 3903 ] {a72f968b-ee84-4d6d-a27f-11620be47c25} 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.10542.altinitytest (altinity build)) (from [::1]:52932) (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:32:51.585683 [ 3903 ] {a72f968b-ee84-4d6d-a27f-11620be47c25} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:52.216900 [ 3894 ] {a8f9f4e3-3ffe-49ef-b873-b515665e7ec0} executeQuery: Code: 36. DB::Exception: Time overflow in function hop: In scope SELECT hop(toDateTime(0), toIntervalDay(1), toIntervalDay(3)). (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48444) (comment: 03013_hop_infinite_loop.sql) (in query: SELECT hop(toDateTime(0), INTERVAL 1 DAY, INTERVAL 3 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008460d8a 4. DB::(anonymous namespace)::TimeWindowImpl<(DB::(anonymous namespace)::TimeWindowFunctionName)3>::dispatchForColumns(std::vector> const&, String const&, unsigned long) @ 0x000000000b5cd413 5. DB::(anonymous namespace)::FunctionTimeWindow<(DB::(anonymous namespace)::TimeWindowFunctionName)3>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b5c3eff 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 2025.10.23 23:32:52.217936 [ 3894 ] {a8f9f4e3-3ffe-49ef-b873-b515665e7ec0} TCPHandler: Code: 36. DB::Exception: Time overflow in function hop: In scope SELECT hop(toDateTime(0), toIntervalDay(1), toIntervalDay(3)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008460d8a 4. DB::(anonymous namespace)::TimeWindowImpl<(DB::(anonymous namespace)::TimeWindowFunctionName)3>::dispatchForColumns(std::vector> const&, String const&, unsigned long) @ 0x000000000b5cd413 5. DB::(anonymous namespace)::FunctionTimeWindow<(DB::(anonymous namespace)::TimeWindowFunctionName)3>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b5c3eff 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 2025.10.23 23:32:52.615247 [ 2902 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_5 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:52.621048 [ 2904 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_5 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:52.922448 [ 3895 ] {cc72323e-a786-433d-82de-65c590455e1f} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Null. (NOT_IMPLEMENTED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48480) (comment: 00726_materialized_view_concurrent.sql) (in query: DROP TABLE src_00726;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000002ffc5e67 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003493f2d5 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:32:52.923555 [ 3895 ] {cc72323e-a786-433d-82de-65c590455e1f} TCPHandler: Code: 48. DB::Exception: Truncate is not supported by storage Null. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000002ffc5e67 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003493f2d5 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:32:53.178095 [ 4070 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_5 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:53.221521 [ 4070 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_5 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:53.889829 [ 4070 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_5 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:53.935630 [ 4070 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_5 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:54.044234 [ 3903 ] {95da9b35-4a15-4652-9412-488c39a100a4} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'x'. In scope SELECT min(b), x AS b FROM (SELECT max(number) FROM numbers(1)). Maybe you meant: ['b']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48504) (comment: 02480_analyzer_alias_nullptr.sql) (in query: SELECT min(b), x AS b FROM (SELECT max(number) FROM numbers(1));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String const&, String&&, String&&) @ 0x00000000334fdb9f 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1139: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000334816bc 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1388: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000033482f89 6. ./src/Analyzer/Resolve/IdentifierLookup.h:47: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033450173 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349d355 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 30. ? @ 0x00007f100c857ac3 31. ? @ 0x00007f100c8e9850 2025.10.23 23:32:54.045741 [ 3903 ] {95da9b35-4a15-4652-9412-488c39a100a4} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'x'. In scope SELECT min(b), x AS b FROM (SELECT max(number) FROM numbers(1)). Maybe you meant: ['b']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String const&, String&&, String&&) @ 0x00000000334fdb9f 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1139: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000334816bc 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1388: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000033482f89 6. ./src/Analyzer/Resolve/IdentifierLookup.h:47: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033450173 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349d355 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 30. ? @ 0x00007f100c857ac3 31. ? @ 0x00007f100c8e9850 2025.10.23 23:32:54.476652 [ 3903 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_5 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:54.518005 [ 3933 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_5 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:55.045638 [ 2902 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_5 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:55.092235 [ 2902 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_5 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:55.220120 [ 4070 ] {da1a90f6-e343-476b-9d7b-012fdc3755ac} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48576) (comment: 01802_test_postgresql_protocol_with_row_policy.sh) (in query: DROP DATABASE db01802), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:32:55.221375 [ 4070 ] {da1a90f6-e343-476b-9d7b-012fdc3755ac} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:32:55.669005 [ 4070 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_5 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:55.715008 [ 3895 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_5 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:56.251140 [ 3895 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_5 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:56.292803 [ 4070 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_5 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:56.641688 [ 3933 ] {1222ad70-c0df-4102-9619-c16a73f0f275} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=729, jobs=715). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48636) (comment: 00632_aggregation_window_funnel.sql) (in query: select 4 = windowFunnel(10000)(timestamp, event = 1000, event = 1001, event = 1002, event = 1008) from funnel_test;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:32:56.643571 [ 3933 ] {1222ad70-c0df-4102-9619-c16a73f0f275} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=729, jobs=715). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:32:56.860902 [ 3933 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_5 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:56.969207 [ 3933 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_5 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:57.181590 [ 3894 ] {cebbcfb1-aee3-4fdd-86b6-36b03cac4565} executeQuery: Code: 497. DB::Exception: user_02916_dictionary_access_test_c2whayj0: Not enough privileges. To execute this query, it's necessary to have the grant dictGet ON test_c2whayj0.dict_02916_dictionary_access_test_c2whayj0. (ACCESS_DENIED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:57974) (comment: 02916_dictionary_access.sh) (in query: SELECT * FROM dictionary(dict_02916_dictionary_access_test_c2whayj0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000312e10fb 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 @ 0x00000000312e0ab3 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x00000000312df5d7 6. ./build_docker/./src/Access/ContextAccess.cpp:825: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x0000000031296331 7. ./src/Access/ContextAccess.h:0: void DB::Context::checkAccessImpl>, std::basic_string_view>>(DB::AccessFlags const&, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x00000000337c440f 8. ./build_docker/./src/Interpreters/Context.cpp:1544: DB::Context::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x00000000337352cf 9. ./build_docker/./src/Storages/StorageDictionary.cpp:0: DB::StorageDictionary::read(std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000038259963 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::IStorage::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000003816ff71 11. ./src/Processors/QueryPlan/QueryPlan.h:53: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000034d80c82 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1777: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d67094 13. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0b8de 14. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cfd8b2 15. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034cf6172 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5bf1 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:32:57.183435 [ 3894 ] {cebbcfb1-aee3-4fdd-86b6-36b03cac4565} TCPHandler: Code: 497. DB::Exception: user_02916_dictionary_access_test_c2whayj0: Not enough privileges. To execute this query, it's necessary to have the grant dictGet ON test_c2whayj0.dict_02916_dictionary_access_test_c2whayj0. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000312e10fb 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 @ 0x00000000312e0ab3 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x00000000312df5d7 6. ./build_docker/./src/Access/ContextAccess.cpp:825: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x0000000031296331 7. ./src/Access/ContextAccess.h:0: void DB::Context::checkAccessImpl>, std::basic_string_view>>(DB::AccessFlags const&, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x00000000337c440f 8. ./build_docker/./src/Interpreters/Context.cpp:1544: DB::Context::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x00000000337352cf 9. ./build_docker/./src/Storages/StorageDictionary.cpp:0: DB::StorageDictionary::read(std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000038259963 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::IStorage::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000003816ff71 11. ./src/Processors/QueryPlan/QueryPlan.h:53: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000034d80c82 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1777: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d67094 13. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0b8de 14. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cfd8b2 15. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034cf6172 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5bf1 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:32:57.595639 [ 3933 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_5 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:57.646677 [ 3933 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_5 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:57.864149 [ 2902 ] {2b4b308b-7789-4227-8d5f-8083f07d0749} executeQuery: Code: 10. DB::Exception: Tuple doesn't have element with index '3': In scope SELECT (t.1).3 FROM t_tuple_numeric. (NOT_FOUND_COLUMN_IN_BLOCK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:58018) (comment: 02286_tuple_numeric_identifier.sql) (in query: SELECT t.1.3 FROM t_tuple_numeric;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000b46526a 4. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x000000001c93c973 5. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c93add2 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083d29bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60aa37 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b609cba 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60b9ac 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334af94d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 2025.10.23 23:32:57.865370 [ 2902 ] {2b4b308b-7789-4227-8d5f-8083f07d0749} TCPHandler: Code: 10. DB::Exception: Tuple doesn't have element with index '3': In scope SELECT (t.1).3 FROM t_tuple_numeric. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000b46526a 4. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x000000001c93c973 5. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c93add2 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083d29bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60aa37 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b609cba 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60b9ac 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334af94d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 2025.10.23 23:32:57.959472 [ 2902 ] {1f007586-cd66-4df4-a3e0-b3a320c48fe5} executeQuery: Code: 10. DB::Exception: Tuple doesn't have element with index '4': In scope SELECT t.4 FROM t_tuple_numeric. (NOT_FOUND_COLUMN_IN_BLOCK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:58018) (comment: 02286_tuple_numeric_identifier.sql) (in query: SELECT t.4 FROM t_tuple_numeric;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000b46526a 4. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x000000001c93c973 5. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c93add2 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083d29bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60aa37 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b609cba 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60b9ac 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334af94d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 2025.10.23 23:32:57.961289 [ 2902 ] {1f007586-cd66-4df4-a3e0-b3a320c48fe5} TCPHandler: Code: 10. DB::Exception: Tuple doesn't have element with index '4': In scope SELECT t.4 FROM t_tuple_numeric. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000b46526a 4. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x000000001c93c973 5. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c93add2 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083d29bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60aa37 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b609cba 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60b9ac 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334af94d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 2025.10.23 23:32:58.211083 [ 4649 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_5 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:58.258759 [ 4649 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_5 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:58.801661 [ 4672 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_5 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:58.842342 [ 4672 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_5 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:59.007618 [ 4070 ] {1a963b77-b536-46fd-9ac5-01c3c109b3bc} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:58144) (comment: 03010_sum_to_to_count_if_nullable.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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000003159b57b 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337550f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e79fb4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:32:59.008932 [ 4070 ] {1a963b77-b536-46fd-9ac5-01c3c109b3bc} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000003159b57b 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337550f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e79fb4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:32:59.269848 [ 3933 ] {ae630322-f115-4078-9d6d-af9ee69add63} executeQuery: Code: 57. DB::Exception: Table db01802.postgresql already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:58212) (comment: 01802_test_postgresql_protocol_with_row_policy.sh) (in query: CREATE TABLE db01802.postgresql (`val` UInt32) ENGINE = MergeTree ORDER BY val SETTINGS index_granularity = 59547, min_bytes_for_wide_part = 790073865, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 17, min_bytes_for_full_part_storage = 165920666, compact_parts_max_bytes_to_buffer = 485409812, compact_parts_max_granules_to_buffer = 141, compact_parts_merge_max_bytes_to_prefetch_part = 13060601, merge_max_block_size = 16778, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 25294601, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 44198, primary_key_compress_block_size = 56137), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:32:59.335561 [ 3933 ] {ae630322-f115-4078-9d6d-af9ee69add63} TCPHandler: Code: 57. DB::Exception: Table db01802.postgresql already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:32:59.405456 [ 3903 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_5 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:59.463339 [ 4713 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_5 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:59.623333 [ 2902 ] {bb694edb-4b73-4bdc-82a1-65294a5b767c} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 't.1.1' in scope SELECT t.`1`.`1`, t.`1`.`2`, t.`2` FROM t_tuple_numeric. Maybe you meant: ['t.1.3']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:58018) (comment: 02286_tuple_numeric_identifier.sql) (in query: SELECT `t`.`1`.`1`, `t`.`1`.`2`, `t`.`2` FROM t_tuple_numeric;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000335017e7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003345512b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:32:59.627649 [ 2902 ] {bb694edb-4b73-4bdc-82a1-65294a5b767c} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 't.1.1' in scope SELECT t.`1`.`1`, t.`1`.`2`, t.`2` FROM t_tuple_numeric. Maybe you meant: ['t.1.3']. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000335017e7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003345512b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:32:59.645117 [ 2902 ] {6fbdf978-c072-4880-b7bf-2ea5cf00b5a8} executeQuery: Code: 57. DB::Exception: Table test_1.t_tuple_numeric already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:58018) (comment: 02286_tuple_numeric_identifier.sql) (in query: CREATE TABLE t_tuple_numeric (t Tuple(Tuple(Int, Int), 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:32:59.645712 [ 2902 ] {6fbdf978-c072-4880-b7bf-2ea5cf00b5a8} TCPHandler: Code: 57. DB::Exception: Table test_1.t_tuple_numeric already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:32:59.929144 [ 4636 ] {f8c205ef-5857-4683-a446-e156aac959f6} executeQuery: Code: 497. DB::Exception: user_02916_dictionary_access_test_c2whayj0: Not enough privileges. To execute this query, it's necessary to have the grant dictGet ON test_c2whayj0.dict_02916_dictionary_access_test_c2whayj0: In scope SELECT dictGet(dict_02916_dictionary_access_test_c2whayj0, 'value', 1). (ACCESS_DENIED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:58220) (comment: 02916_dictionary_access.sh) (in query: SELECT dictGet(dict_02916_dictionary_access_test_c2whayj0, '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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000312e10fb 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 @ 0x00000000312e0ab3 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x00000000312df5d7 6. ./build_docker/./src/Access/ContextAccess.cpp:825: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x0000000031296331 7. ./src/Access/ContextAccess.h:0: void DB::Context::checkAccessImpl>, std::basic_string_view>>(DB::AccessFlags const&, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x00000000337c440f 8. ./build_docker/./src/Interpreters/Context.cpp:1544: DB::Context::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x00000000337352cf 9. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000096b01aa 10. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000096a4dc4 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 12. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 19. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 22. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034cf4284 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 2025.10.23 23:32:59.930457 [ 4636 ] {f8c205ef-5857-4683-a446-e156aac959f6} TCPHandler: Code: 497. DB::Exception: user_02916_dictionary_access_test_c2whayj0: Not enough privileges. To execute this query, it's necessary to have the grant dictGet ON test_c2whayj0.dict_02916_dictionary_access_test_c2whayj0: In scope SELECT dictGet(dict_02916_dictionary_access_test_c2whayj0, '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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000312e10fb 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 @ 0x00000000312e0ab3 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x00000000312df5d7 6. ./build_docker/./src/Access/ContextAccess.cpp:825: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x0000000031296331 7. ./src/Access/ContextAccess.h:0: void DB::Context::checkAccessImpl>, std::basic_string_view>>(DB::AccessFlags const&, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x00000000337c440f 8. ./build_docker/./src/Interpreters/Context.cpp:1544: DB::Context::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x00000000337352cf 9. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000096b01aa 10. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000096a4dc4 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 12. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 19. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 22. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034cf4284 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 2025.10.23 23:33:00.029821 [ 4745 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_5 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:00.082029 [ 4745 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_5 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:00.700427 [ 4752 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_5 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:00.832191 [ 4799 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_5 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:01.493208 [ 4841 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_5 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:01.503584 [ 4712 ] {e2e56a5d-04d1-4115-99ab-dc2ae0885306} executeQuery: Code: 36. DB::Exception: Frame start offset for 'RANGE' frame must be a nonnegative 32-bit integer, '0.' of type 'Float64' given. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:58338) (comment: 02833_window_func_range_offset.sql) (in query: -- invalid start offset with RANGE SELECT count() OVER (ORDER BY 3.4028234663852886e38 RANGE BETWEEN 0.0 PRECEDING AND UNBOUNDED FOLLOWING);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x000000003577bd97 4. ./build_docker/./src/Interpreters/WindowDescription.cpp:100: DB::WindowFrame::checkValid() const @ 0x000000003577a9db 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d8a7f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3172: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a5b3d 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 2025.10.23 23:33:01.504501 [ 4712 ] {e2e56a5d-04d1-4115-99ab-dc2ae0885306} TCPHandler: Code: 36. DB::Exception: Frame start offset for 'RANGE' frame must be a nonnegative 32-bit integer, '0.' of type 'Float64' given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x000000003577bd97 4. ./build_docker/./src/Interpreters/WindowDescription.cpp:100: DB::WindowFrame::checkValid() const @ 0x000000003577a9db 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d8a7f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3172: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a5b3d 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 2025.10.23 23:33:01.514570 [ 4712 ] {69f354d0-0589-44d1-bfe7-8c52de3634b1} executeQuery: Code: 36. DB::Exception: Frame start offset for 'RANGE' frame must be a nonnegative 32-bit integer, 'nan' of type 'Float64' given. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:58338) (comment: 02833_window_func_range_offset.sql) (in query: SELECT count() OVER (ORDER BY 3.4028234663852886e38 RANGE BETWEEN nan PRECEDING AND UNBOUNDED FOLLOWING);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x000000003577bd97 4. ./build_docker/./src/Interpreters/WindowDescription.cpp:100: DB::WindowFrame::checkValid() const @ 0x000000003577a9db 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d8a7f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3172: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a5b3d 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 2025.10.23 23:33:01.515099 [ 4712 ] {69f354d0-0589-44d1-bfe7-8c52de3634b1} TCPHandler: Code: 36. DB::Exception: Frame start offset for 'RANGE' frame must be a nonnegative 32-bit integer, 'nan' of type 'Float64' given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x000000003577bd97 4. ./build_docker/./src/Interpreters/WindowDescription.cpp:100: DB::WindowFrame::checkValid() const @ 0x000000003577a9db 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d8a7f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3172: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a5b3d 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 2025.10.23 23:33:01.551218 [ 4636 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_5 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:01.878153 [ 4799 ] {b5b6b294-c70a-45f2-ba5e-65684a73522e} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:58484) (comment: 02543_alter_update_rename_stuck.sh) (in query: SELECT count() from system.mutations where database='test_11' and table='table_to_rename'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:33:01.880699 [ 4799 ] {b5b6b294-c70a-45f2-ba5e-65684a73522e} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:33:02.116287 [ 4841 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_5 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:02.162582 [ 4636 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_5 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:02.272133 [ 4745 ] {37d751a3-69a2-43b1-aa21-0e8d1245c427} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02916_dictionary_access.sh) (in query: /* ddl_entry=query-0000000003 */ DROP DICTIONARY IF EXISTS test_c2whayj0.dict_02916_dictionary_access_test_c2whayj0 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349417ab 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003395fc9e 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000033958fac 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ad726d 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a52a3c 14. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:222: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003493e6e9 15. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 16. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 17. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 27. ? @ 0x00007f100c857ac3 28. ? @ 0x00007f100c8e9850 2025.10.23 23:33:02.278295 [ 4745 ] {37d751a3-69a2-43b1-aa21-0e8d1245c427} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:58430) (comment: 02916_dictionary_access.sh) (in query: DROP DICTIONARY IF EXISTS dict_02916_dictionary_access_test_c2whayj0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349417ab 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003395fc9e 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000033958fac 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ad726d 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a52a3c 14. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:222: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003493e6e9 15. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 16. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 17. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 27. ? @ 0x00007f100c857ac3 28. ? @ 0x00007f100c8e9850 2025.10.23 23:33:02.279313 [ 4745 ] {37d751a3-69a2-43b1-aa21-0e8d1245c427} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349417ab 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003395fc9e 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000033958fac 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ad726d 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a52a3c 14. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:222: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003493e6e9 15. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 16. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 17. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 27. ? @ 0x00007f100c857ac3 28. ? @ 0x00007f100c8e9850 2025.10.23 23:33:02.831184 [ 4712 ] {d4b0eb5b-010e-4d3a-82aa-176922b78d34} executeQuery: Code: 36. DB::Exception: Frame end offset for 'RANGE' frame must be a nonnegative 32-bit integer, '0.' of type 'Float64' given. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:58338) (comment: 02833_window_func_range_offset.sql) (in query: -- invalid end offset with RANGE SELECT count() OVER (ORDER BY 3.4028234663852886e38 RANGE BETWEEN UNBOUNDED PRECEDING AND 0.0 FOLLOWING);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x000000003577bd97 4. ./build_docker/./src/Interpreters/WindowDescription.cpp:113: DB::WindowFrame::checkValid() const @ 0x000000003577ac50 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d8a7f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3172: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a5b3d 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 2025.10.23 23:33:02.832085 [ 4712 ] {d4b0eb5b-010e-4d3a-82aa-176922b78d34} TCPHandler: Code: 36. DB::Exception: Frame end offset for 'RANGE' frame must be a nonnegative 32-bit integer, '0.' of type 'Float64' given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x000000003577bd97 4. ./build_docker/./src/Interpreters/WindowDescription.cpp:113: DB::WindowFrame::checkValid() const @ 0x000000003577ac50 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d8a7f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3172: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a5b3d 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 2025.10.23 23:33:02.841680 [ 4712 ] {5de3f4d2-225d-494b-8571-910abc99617e} executeQuery: Code: 36. DB::Exception: Frame end offset for 'RANGE' frame must be a nonnegative 32-bit integer, 'nan' of type 'Float64' given. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:58338) (comment: 02833_window_func_range_offset.sql) (in query: SELECT count() OVER (ORDER BY 3.4028234663852886e38 RANGE BETWEEN UNBOUNDED PRECEDING AND nan FOLLOWING);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x000000003577bd97 4. ./build_docker/./src/Interpreters/WindowDescription.cpp:113: DB::WindowFrame::checkValid() const @ 0x000000003577ac50 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d8a7f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3172: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a5b3d 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 2025.10.23 23:33:02.842290 [ 4712 ] {5de3f4d2-225d-494b-8571-910abc99617e} TCPHandler: Code: 36. DB::Exception: Frame end offset for 'RANGE' frame must be a nonnegative 32-bit integer, 'nan' of type 'Float64' given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x000000003577bd97 4. ./build_docker/./src/Interpreters/WindowDescription.cpp:113: DB::WindowFrame::checkValid() const @ 0x000000003577ac50 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d8a7f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3172: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a5b3d 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 2025.10.23 23:33:02.938678 [ 4841 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_5 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:02.987264 [ 4712 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_5 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:03.346298 [ 2904 ] {37a1e6eb-ffdd-4dd8-a0df-b869eb9352ab} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48646) (comment: 02916_dictionary_access.sh) (in query: DROP DATABASE IF EXISTS test_c2whayj0 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349417ab 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>>>&) @ 0x0000000034947b8d 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:33:03.347494 [ 2904 ] {37a1e6eb-ffdd-4dd8-a0df-b869eb9352ab} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349417ab 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>>>&) @ 0x0000000034947b8d 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:03.361979 [ 4752 ] {17720eb3-250f-4bf9-a585-58c4b6db2845} executeQuery: Code: 20. DB::Exception: Number of columns in section IN doesn't match. 1 at left, 2 at right.: while executing 'FUNCTION nullIn(str : 0, __set_16375844943893890210_5412506258507699276 :: 1) -> nullIn(__table1.str, __set_16375844943893890210_5412506258507699276) UInt8 : 2': While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:58468) (comment: 01681_bloom_filter_nullable_column.sql) (in query: SELECT * FROM bloom_filter_nullable_index WHERE str IN (SELECT '1048576', str FROM bloom_filter_nullable_index) SETTINGS transform_null_in = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&&) @ 0x000000000860b48d 4. ./build_docker/./src/Interpreters/Set.cpp:458: DB::Set::execute(std::vector> const&, bool) const @ 0x00000000350e4f4c 5. DB::(anonymous namespace)::FunctionIn::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012ef08aa 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d57db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffeaa 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a24ade 11. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a29c4e 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::MergeTreeRangeReader::executePrewhereActionsAndFilterColumns(DB::MergeTreeRangeReader::ReadResult&) const @ 0x0000000039cd88a8 13. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000039cd27a2 14. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:978: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000039ccec52 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000039d4a566 16. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000003bfe52b4 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:206: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d3c6b0 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf89b85 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 24. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 25. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 27. ? @ 0x00007f100c857ac3 28. ? @ 0x00007f100c8e9850 2025.10.23 23:33:03.363880 [ 4752 ] {17720eb3-250f-4bf9-a585-58c4b6db2845} TCPHandler: Code: 20. DB::Exception: Number of columns in section IN doesn't match. 1 at left, 2 at right.: while executing 'FUNCTION nullIn(str : 0, __set_16375844943893890210_5412506258507699276 :: 1) -> nullIn(__table1.str, __set_16375844943893890210_5412506258507699276) UInt8 : 2': While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (NUMBER_OF_COLUMNS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&&) @ 0x000000000860b48d 4. ./build_docker/./src/Interpreters/Set.cpp:458: DB::Set::execute(std::vector> const&, bool) const @ 0x00000000350e4f4c 5. DB::(anonymous namespace)::FunctionIn::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012ef08aa 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d57db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffeaa 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a24ade 11. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a29c4e 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::MergeTreeRangeReader::executePrewhereActionsAndFilterColumns(DB::MergeTreeRangeReader::ReadResult&) const @ 0x0000000039cd88a8 13. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000039cd27a2 14. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:978: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000039ccec52 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000039d4a566 16. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000003bfe52b4 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:206: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d3c6b0 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf89b85 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 24. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 25. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 27. ? @ 0x00007f100c857ac3 28. ? @ 0x00007f100c8e9850 2025.10.23 23:33:03.403467 [ 4752 ] {533de0a9-ae97-46df-b3b8-531b8ff53647} executeQuery: Code: 20. DB::Exception: Number of columns in section IN doesn't match. 1 at left, 2 at right.: while executing 'FUNCTION nullIn(str : 0, __set_16375844943893890210_5412506258507699276 :: 1) -> nullIn(__table1.str, __set_16375844943893890210_5412506258507699276) UInt8 : 2': While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:58468) (comment: 01681_bloom_filter_nullable_column.sql) (in query: SELECT * FROM bloom_filter_nullable_index WHERE str IN (SELECT '1048576', str FROM bloom_filter_nullable_index) SETTINGS transform_null_in = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&&) @ 0x000000000860b48d 4. ./build_docker/./src/Interpreters/Set.cpp:458: DB::Set::execute(std::vector> const&, bool) const @ 0x00000000350e4f4c 5. DB::(anonymous namespace)::FunctionIn::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012ef08aa 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d57db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffeaa 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a24ade 11. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a29c4e 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::MergeTreeRangeReader::executePrewhereActionsAndFilterColumns(DB::MergeTreeRangeReader::ReadResult&) const @ 0x0000000039cd88a8 13. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000039cd27a2 14. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:978: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000039ccec52 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000039d4a566 16. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000003bfe52b4 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:206: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d3c6b0 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf89b85 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 24. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 25. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 27. ? @ 0x00007f100c857ac3 28. ? @ 0x00007f100c8e9850 2025.10.23 23:33:03.404525 [ 4752 ] {533de0a9-ae97-46df-b3b8-531b8ff53647} TCPHandler: Code: 20. DB::Exception: Number of columns in section IN doesn't match. 1 at left, 2 at right.: while executing 'FUNCTION nullIn(str : 0, __set_16375844943893890210_5412506258507699276 :: 1) -> nullIn(__table1.str, __set_16375844943893890210_5412506258507699276) UInt8 : 2': While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (NUMBER_OF_COLUMNS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&&) @ 0x000000000860b48d 4. ./build_docker/./src/Interpreters/Set.cpp:458: DB::Set::execute(std::vector> const&, bool) const @ 0x00000000350e4f4c 5. DB::(anonymous namespace)::FunctionIn::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012ef08aa 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d57db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffeaa 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a24ade 11. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000033a29c4e 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::MergeTreeRangeReader::executePrewhereActionsAndFilterColumns(DB::MergeTreeRangeReader::ReadResult&) const @ 0x0000000039cd88a8 13. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000039cd27a2 14. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:978: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000039ccec52 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000039d4a566 16. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000003bfe52b4 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:206: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d3c6b0 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf89b85 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 24. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 25. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 27. ? @ 0x00007f100c857ac3 28. ? @ 0x00007f100c8e9850 2025.10.23 23:33:03.498497 [ 3894 ] {33121def-073d-4dba-aae6-1753abf344f1} executeQuery: Code: 43. DB::Exception: The INTERVAL must be a week or shorter, 'IntervalMonth' given. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:58256) (comment: 02346_non_negative_derivative.sql) (in query: -- shall not work for month, quarter, year (intervals with floating number of seconds) -- Month SELECT ts, metric, nonNegativeDerivative(metric, ts, INTERVAL 11 MONTH) OVER (PARTITION BY metric ORDER BY ts, metric ASC Rows BETWEEN UNBOUNDED PRECEDING AND UNBOUNDED FOLLOWING) AS deriv FROM nnd;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2566: DB::NonNegativeDerivativeParams::NonNegativeDerivativeParams(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003ba893eb 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2586: DB::WindowFunctionNonNegativeDerivative::WindowFunctionNonNegativeDerivative(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003ba8804b 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], String const&, std::vector, std::allocator>> const&, DB::Array const&, void>(std::allocator const&, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003ba87813 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000003ba44137 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306e2801 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 @ 0x00000000306dcf59 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3167: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a59ff 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 2025.10.23 23:33:03.499308 [ 3894 ] {33121def-073d-4dba-aae6-1753abf344f1} TCPHandler: Code: 43. DB::Exception: The INTERVAL must be a week or shorter, 'IntervalMonth' given. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2566: DB::NonNegativeDerivativeParams::NonNegativeDerivativeParams(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003ba893eb 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2586: DB::WindowFunctionNonNegativeDerivative::WindowFunctionNonNegativeDerivative(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003ba8804b 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], String const&, std::vector, std::allocator>> const&, DB::Array const&, void>(std::allocator const&, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003ba87813 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000003ba44137 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306e2801 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 @ 0x00000000306dcf59 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3167: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a59ff 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 2025.10.23 23:33:03.513602 [ 3894 ] {9d063924-960f-487f-b4eb-33a1506ce88e} executeQuery: Code: 43. DB::Exception: The INTERVAL must be a week or shorter, 'IntervalQuarter' given. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:58256) (comment: 02346_non_negative_derivative.sql) (in query: -- Quarter SELECT ts, metric, nonNegativeDerivative(metric, ts, INTERVAL 12 QUARTER) OVER (PARTITION BY metric ORDER BY ts, metric ASC Rows BETWEEN UNBOUNDED PRECEDING AND UNBOUNDED FOLLOWING) AS deriv FROM nnd;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2566: DB::NonNegativeDerivativeParams::NonNegativeDerivativeParams(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003ba893eb 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2586: DB::WindowFunctionNonNegativeDerivative::WindowFunctionNonNegativeDerivative(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003ba8804b 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], String const&, std::vector, std::allocator>> const&, DB::Array const&, void>(std::allocator const&, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003ba87813 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000003ba44137 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306e2801 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 @ 0x00000000306dcf59 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3167: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a59ff 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 2025.10.23 23:33:03.514364 [ 3894 ] {9d063924-960f-487f-b4eb-33a1506ce88e} TCPHandler: Code: 43. DB::Exception: The INTERVAL must be a week or shorter, 'IntervalQuarter' given. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2566: DB::NonNegativeDerivativeParams::NonNegativeDerivativeParams(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003ba893eb 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2586: DB::WindowFunctionNonNegativeDerivative::WindowFunctionNonNegativeDerivative(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003ba8804b 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], String const&, std::vector, std::allocator>> const&, DB::Array const&, void>(std::allocator const&, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003ba87813 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000003ba44137 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306e2801 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 @ 0x00000000306dcf59 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3167: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a59ff 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 2025.10.23 23:33:03.522442 [ 4841 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_5 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:03.528122 [ 3894 ] {9d245a72-2a0a-47cf-a0a8-9c923a8aa254} executeQuery: Code: 43. DB::Exception: The INTERVAL must be a week or shorter, 'IntervalYear' given. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:58256) (comment: 02346_non_negative_derivative.sql) (in query: -- Year SELECT ts, metric, nonNegativeDerivative(metric, ts, INTERVAL 13 YEAR) OVER (PARTITION BY metric ORDER BY ts, metric ASC Rows BETWEEN UNBOUNDED PRECEDING AND UNBOUNDED FOLLOWING) AS deriv FROM nnd;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2566: DB::NonNegativeDerivativeParams::NonNegativeDerivativeParams(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003ba893eb 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2586: DB::WindowFunctionNonNegativeDerivative::WindowFunctionNonNegativeDerivative(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003ba8804b 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], String const&, std::vector, std::allocator>> const&, DB::Array const&, void>(std::allocator const&, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003ba87813 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000003ba44137 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306e2801 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 @ 0x00000000306dcf59 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3167: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a59ff 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 2025.10.23 23:33:03.528870 [ 3894 ] {9d245a72-2a0a-47cf-a0a8-9c923a8aa254} TCPHandler: Code: 43. DB::Exception: The INTERVAL must be a week or shorter, 'IntervalYear' given. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2566: DB::NonNegativeDerivativeParams::NonNegativeDerivativeParams(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003ba893eb 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2586: DB::WindowFunctionNonNegativeDerivative::WindowFunctionNonNegativeDerivative(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003ba8804b 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], String const&, std::vector, std::allocator>> const&, DB::Array const&, void>(std::allocator const&, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003ba87813 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000003ba44137 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306e2801 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 @ 0x00000000306dcf59 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3167: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a59ff 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 2025.10.23 23:33:03.568951 [ 4841 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_5 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:03.796472 [ 4841 ] {143317d0-3625-420a-8f97-68da8bee0903} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=729, jobs=712). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:58670) (comment: 03198_orc_read_time_zone.sh) (in query: select * from test_orc_read_timezone SETTINGS session_timezone='Asia/Shanghai'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:33:03.889673 [ 4841 ] {143317d0-3625-420a-8f97-68da8bee0903} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=729, jobs=712). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:33:04.181063 [ 4636 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_5 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:04.229696 [ 4636 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_5 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:04.546477 [ 2904 ] {85b27022-3cc2-442b-9ad8-cf7bebd07b8b} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '2bb15604e207:9000:bc43afb3-f96f-4f51-a0ea-56a3f0c3ec5d', current host ID: '2bb15604e207:9000:94976892-c3bd-4bfb-98ad-c830976f4610'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48680) (comment: 02124_insert_deduplication_token_multiple_blocks_replica.sh) (in query: CREATE DATABASE IF NOT EXISTS test_mackea43 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032aa1b87 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a1ca94 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a2d4bd 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000349197cf 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000348953f8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:33:04.548060 [ 2904 ] {85b27022-3cc2-442b-9ad8-cf7bebd07b8b} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '2bb15604e207:9000:bc43afb3-f96f-4f51-a0ea-56a3f0c3ec5d', current host ID: '2bb15604e207:9000:94976892-c3bd-4bfb-98ad-c830976f4610'. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032aa1b87 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a1ca94 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a2d4bd 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000349197cf 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000348953f8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:04.561560 [ 2904 ] {d9af2fc8-d874-4a63-96cb-a1556d5a636f} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '2bb15604e207:9000:bc43afb3-f96f-4f51-a0ea-56a3f0c3ec5d', current host ID: '2bb15604e207:9000:2f319217-8140-4475-b873-3456ed83cff4'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48710) (comment: 02514_null_dictionary_source.sql) (in query: CREATE DATABASE IF NOT EXISTS test_wbnkf1ui 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032aa1b87 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a1ca94 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a2d4bd 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000349197cf 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000348953f8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:33:04.562821 [ 2904 ] {d9af2fc8-d874-4a63-96cb-a1556d5a636f} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '2bb15604e207:9000:bc43afb3-f96f-4f51-a0ea-56a3f0c3ec5d', current host ID: '2bb15604e207:9000:2f319217-8140-4475-b873-3456ed83cff4'. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032aa1b87 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a1ca94 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a2d4bd 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000349197cf 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000348953f8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:04.576090 [ 2904 ] {3bba2782-f98b-40a0-bb52-f6ca17004bf6} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '2bb15604e207:9000:bc43afb3-f96f-4f51-a0ea-56a3f0c3ec5d', current host ID: '2bb15604e207:9000:80057bc0-f0b4-467e-ad20-4615e9e33ca9'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48726) (comment: 00429_point_in_ellipses.sql) (in query: CREATE DATABASE IF NOT EXISTS test_42lurffx 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032aa1b87 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a1ca94 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a2d4bd 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000349197cf 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000348953f8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:33:04.577632 [ 2904 ] {3bba2782-f98b-40a0-bb52-f6ca17004bf6} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '2bb15604e207:9000:bc43afb3-f96f-4f51-a0ea-56a3f0c3ec5d', current host ID: '2bb15604e207:9000:80057bc0-f0b4-467e-ad20-4615e9e33ca9'. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032aa1b87 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a1ca94 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a2d4bd 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000349197cf 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000348953f8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:04.593186 [ 4752 ] {2ec472b2-9a73-4d29-98c7-f91550e6bb3f} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '2bb15604e207:9000:bc43afb3-f96f-4f51-a0ea-56a3f0c3ec5d', current host ID: '2bb15604e207:9000:4d06239b-7c7a-4e8c-8782-0fe0a4eaef9c'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48728) (comment: 00257_shard_no_aggregates_and_constant_keys.sql) (in query: CREATE DATABASE IF NOT EXISTS test_lyai2f99 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032aa1b87 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a1ca94 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a2d4bd 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000349197cf 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000348953f8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:33:04.594587 [ 4752 ] {2ec472b2-9a73-4d29-98c7-f91550e6bb3f} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '2bb15604e207:9000:bc43afb3-f96f-4f51-a0ea-56a3f0c3ec5d', current host ID: '2bb15604e207:9000:4d06239b-7c7a-4e8c-8782-0fe0a4eaef9c'. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032aa1b87 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a1ca94 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a2d4bd 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000349197cf 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000348953f8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:04.608708 [ 4752 ] {f7624c90-507d-4f37-8f74-5f9a2e3f38a6} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '2bb15604e207:9000:bc43afb3-f96f-4f51-a0ea-56a3f0c3ec5d', current host ID: '2bb15604e207:9000:33a1e15e-e136-4869-8178-93bf2edfe5d2'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48740) (comment: 02319_sql_standard_create_drop_index.sql) (in query: CREATE DATABASE IF NOT EXISTS test_by0abu3a 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032aa1b87 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a1ca94 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a2d4bd 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000349197cf 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000348953f8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:33:04.610128 [ 4752 ] {f7624c90-507d-4f37-8f74-5f9a2e3f38a6} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '2bb15604e207:9000:bc43afb3-f96f-4f51-a0ea-56a3f0c3ec5d', current host ID: '2bb15604e207:9000:33a1e15e-e136-4869-8178-93bf2edfe5d2'. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032aa1b87 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a1ca94 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a2d4bd 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000349197cf 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000348953f8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:04.626620 [ 4752 ] {55680a36-d25b-441c-831c-9f9aed682f1c} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '2bb15604e207:9000:bc43afb3-f96f-4f51-a0ea-56a3f0c3ec5d', current host ID: '2bb15604e207:9000:d01bb739-dc8c-489f-b3a9-812c71a8121e'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48752) (comment: 00417_system_build_options.sh) (in query: CREATE DATABASE IF NOT EXISTS test_ps7coq9o 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032aa1b87 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a1ca94 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a2d4bd 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000349197cf 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000348953f8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:33:04.628071 [ 4752 ] {55680a36-d25b-441c-831c-9f9aed682f1c} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '2bb15604e207:9000:bc43afb3-f96f-4f51-a0ea-56a3f0c3ec5d', current host ID: '2bb15604e207:9000:d01bb739-dc8c-489f-b3a9-812c71a8121e'. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032aa1b87 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a1ca94 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a2d4bd 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000349197cf 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000348953f8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:04.742248 [ 4752 ] {24faf386-6d18-4dac-9b65-5e79bfe85738} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '2bb15604e207:9000:bc43afb3-f96f-4f51-a0ea-56a3f0c3ec5d', current host ID: '2bb15604e207:9000:3dcac4ed-dc1f-4c19-86ed-3c20e7460ffb'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48766) (comment: 02132_empty_mutation_livelock.sql) (in query: CREATE DATABASE IF NOT EXISTS test_1mpia0o2 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032aa1b87 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a1ca94 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a2d4bd 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000349197cf 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000348953f8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:33:04.743819 [ 4752 ] {24faf386-6d18-4dac-9b65-5e79bfe85738} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '2bb15604e207:9000:bc43afb3-f96f-4f51-a0ea-56a3f0c3ec5d', current host ID: '2bb15604e207:9000:3dcac4ed-dc1f-4c19-86ed-3c20e7460ffb'. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032aa1b87 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a1ca94 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a2d4bd 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000349197cf 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000348953f8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:04.756996 [ 2904 ] {c7ef5fdd-1198-42e1-8c71-09dcda06df4d} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '2bb15604e207:9000:bc43afb3-f96f-4f51-a0ea-56a3f0c3ec5d', current host ID: '2bb15604e207:9000:5b25ccbf-bdd1-4ae8-a530-78538bd31a5f'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48782) (comment: 01353_topk_enum.sql) (in query: CREATE DATABASE IF NOT EXISTS test_z7t4vlmb 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032aa1b87 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a1ca94 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a2d4bd 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000349197cf 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000348953f8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:33:04.758245 [ 2904 ] {c7ef5fdd-1198-42e1-8c71-09dcda06df4d} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '2bb15604e207:9000:bc43afb3-f96f-4f51-a0ea-56a3f0c3ec5d', current host ID: '2bb15604e207:9000:5b25ccbf-bdd1-4ae8-a530-78538bd31a5f'. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032aa1b87 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a1ca94 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a2d4bd 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000349197cf 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000348953f8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:04.790808 [ 2904 ] {18c4916e-490c-49b3-a26e-5060e39c6d5e} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '2bb15604e207:9000:bc43afb3-f96f-4f51-a0ea-56a3f0c3ec5d', current host ID: '2bb15604e207:9000:774d94b0-7105-4bff-83fb-df8c466def38'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48796) (comment: 02943_variant_type_with_different_local_and_global_order.sh) (in query: CREATE DATABASE IF NOT EXISTS test_5pjd8j7w 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032aa1b87 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a1ca94 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a2d4bd 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000349197cf 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000348953f8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:33:04.842443 [ 2904 ] {18c4916e-490c-49b3-a26e-5060e39c6d5e} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '2bb15604e207:9000:bc43afb3-f96f-4f51-a0ea-56a3f0c3ec5d', current host ID: '2bb15604e207:9000:774d94b0-7105-4bff-83fb-df8c466def38'. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032aa1b87 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a1ca94 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a2d4bd 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000349197cf 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000348953f8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:04.865108 [ 4745 ] {510ed874-96d9-4fd4-b9d1-13deb13a08a0} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '2bb15604e207:9000:bc43afb3-f96f-4f51-a0ea-56a3f0c3ec5d', current host ID: '2bb15604e207:9000:7177e961-4c62-456f-b165-5e8d17173d31'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48810) (comment: 03167_base64_url_functions_sh.sh) (in query: CREATE DATABASE IF NOT EXISTS test_ln2x0ose 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032aa1b87 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a1ca94 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a2d4bd 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000349197cf 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000348953f8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:33:04.866425 [ 4745 ] {510ed874-96d9-4fd4-b9d1-13deb13a08a0} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '2bb15604e207:9000:bc43afb3-f96f-4f51-a0ea-56a3f0c3ec5d', current host ID: '2bb15604e207:9000:7177e961-4c62-456f-b165-5e8d17173d31'. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032aa1b87 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a1ca94 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a2d4bd 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000349197cf 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000348953f8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:04.879361 [ 4745 ] {3f01ee95-5485-47a6-b65d-98b86880b0e9} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '2bb15604e207:9000:bc43afb3-f96f-4f51-a0ea-56a3f0c3ec5d', current host ID: '2bb15604e207:9000:145c4a04-194f-4f2b-8264-5d864bec26fb'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48818) (comment: 03008_deduplication_remote_insert_select.sql) (in query: CREATE DATABASE IF NOT EXISTS test_windpspc 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032aa1b87 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a1ca94 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a2d4bd 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000349197cf 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000348953f8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:33:04.880897 [ 4745 ] {3f01ee95-5485-47a6-b65d-98b86880b0e9} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '2bb15604e207:9000:bc43afb3-f96f-4f51-a0ea-56a3f0c3ec5d', current host ID: '2bb15604e207:9000:145c4a04-194f-4f2b-8264-5d864bec26fb'. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032aa1b87 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a1ca94 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a2d4bd 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000349197cf 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000348953f8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:04.926257 [ 4745 ] {66c5a76a-573e-4726-8e42-5603a96786be} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '2bb15604e207:9000:bc43afb3-f96f-4f51-a0ea-56a3f0c3ec5d', current host ID: '2bb15604e207:9000:e32ef835-1c68-4c79-ade1-922911a1b483'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44194) (comment: 03040_dynamic_type_alters_1_memory.sql) (in query: CREATE DATABASE IF NOT EXISTS test_q5hkhbxq 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032aa1b87 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a1ca94 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a2d4bd 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000349197cf 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000348953f8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:33:04.927917 [ 4745 ] {66c5a76a-573e-4726-8e42-5603a96786be} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '2bb15604e207:9000:bc43afb3-f96f-4f51-a0ea-56a3f0c3ec5d', current host ID: '2bb15604e207:9000:e32ef835-1c68-4c79-ade1-922911a1b483'. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032aa1b87 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a1ca94 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a2d4bd 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000349197cf 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000348953f8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:04.941102 [ 4745 ] {b7d0ec3f-045e-4573-b76e-3a434196272a} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '2bb15604e207:9000:bc43afb3-f96f-4f51-a0ea-56a3f0c3ec5d', current host ID: '2bb15604e207:9000:e65704db-3034-4838-ab21-fa6217cd13da'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44208) (comment: 02097_default_dict_get_add_database.sql) (in query: CREATE DATABASE IF NOT EXISTS test_n9ypohnz 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032aa1b87 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a1ca94 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a2d4bd 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000349197cf 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000348953f8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:33:04.942416 [ 4745 ] {b7d0ec3f-045e-4573-b76e-3a434196272a} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '2bb15604e207:9000:bc43afb3-f96f-4f51-a0ea-56a3f0c3ec5d', current host ID: '2bb15604e207:9000:e65704db-3034-4838-ab21-fa6217cd13da'. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032aa1b87 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a1ca94 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a2d4bd 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000349197cf 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000348953f8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:04.954766 [ 4745 ] {940c92ba-4fee-4c28-a779-6e0ffb5add30} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '2bb15604e207:9000:bc43afb3-f96f-4f51-a0ea-56a3f0c3ec5d', current host ID: '2bb15604e207:9000:60b565c0-2aea-4eb0-a0f9-d19af66f2338'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44224) (comment: 03248_invalid_where.sql) (in query: CREATE DATABASE IF NOT EXISTS test_k7rxg37b 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032aa1b87 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a1ca94 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a2d4bd 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000349197cf 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000348953f8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:33:04.956114 [ 4745 ] {940c92ba-4fee-4c28-a779-6e0ffb5add30} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '2bb15604e207:9000:bc43afb3-f96f-4f51-a0ea-56a3f0c3ec5d', current host ID: '2bb15604e207:9000:60b565c0-2aea-4eb0-a0f9-d19af66f2338'. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032aa1b87 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a1ca94 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a2d4bd 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000349197cf 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000348953f8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:04.967672 [ 4745 ] {dd8fdaf4-756e-4b26-9d10-ff60ceb0de8c} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '2bb15604e207:9000:bc43afb3-f96f-4f51-a0ea-56a3f0c3ec5d', current host ID: '2bb15604e207:9000:731a14a7-a962-4e13-b1d9-a037a017c98c'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44232) (comment: 02460_prewhere_row_level_policy.sql) (in query: CREATE DATABASE IF NOT EXISTS test_7prvs9c1 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032aa1b87 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a1ca94 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a2d4bd 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000349197cf 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000348953f8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:33:04.969065 [ 4745 ] {dd8fdaf4-756e-4b26-9d10-ff60ceb0de8c} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '2bb15604e207:9000:bc43afb3-f96f-4f51-a0ea-56a3f0c3ec5d', current host ID: '2bb15604e207:9000:731a14a7-a962-4e13-b1d9-a037a017c98c'. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032aa1b87 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a1ca94 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a2d4bd 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000349197cf 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000348953f8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:04.980782 [ 4745 ] {93fd4a10-daf8-4aac-bb73-dab91a8a1c43} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '2bb15604e207:9000:bc43afb3-f96f-4f51-a0ea-56a3f0c3ec5d', current host ID: '2bb15604e207:9000:88788ccd-4f72-454d-bebe-e9175388c2fa'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44236) (comment: 02916_local_insert_into_function.sh) (in query: CREATE DATABASE IF NOT EXISTS test_6dqhz9aj 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032aa1b87 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a1ca94 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a2d4bd 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000349197cf 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000348953f8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:33:04.982004 [ 4745 ] {93fd4a10-daf8-4aac-bb73-dab91a8a1c43} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '2bb15604e207:9000:bc43afb3-f96f-4f51-a0ea-56a3f0c3ec5d', current host ID: '2bb15604e207:9000:88788ccd-4f72-454d-bebe-e9175388c2fa'. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032aa1b87 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a1ca94 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a2d4bd 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000349197cf 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000348953f8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:04.992979 [ 4745 ] {152b7321-9700-4c13-aaf8-f67960cb5fe2} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '2bb15604e207:9000:bc43afb3-f96f-4f51-a0ea-56a3f0c3ec5d', current host ID: '2bb15604e207:9000:c130129c-e45c-4a38-8b94-0654b27e3ea4'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44252) (comment: 01881_total_bytes_storage_buffer.sql) (in query: CREATE DATABASE IF NOT EXISTS test_zv7w3665 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032aa1b87 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a1ca94 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a2d4bd 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000349197cf 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000348953f8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:33:04.994050 [ 4745 ] {152b7321-9700-4c13-aaf8-f67960cb5fe2} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '2bb15604e207:9000:bc43afb3-f96f-4f51-a0ea-56a3f0c3ec5d', current host ID: '2bb15604e207:9000:c130129c-e45c-4a38-8b94-0654b27e3ea4'. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032aa1b87 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a1ca94 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a2d4bd 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000349197cf 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000348953f8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:05.005238 [ 4745 ] {8ab30c6b-0126-41b8-9dc3-d24f87f56130} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '2bb15604e207:9000:bc43afb3-f96f-4f51-a0ea-56a3f0c3ec5d', current host ID: '2bb15604e207:9000:9ce8c158-8062-432f-9f4e-08f590746e84'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44262) (comment: 01825_new_type_json_9.sql) (in query: CREATE DATABASE IF NOT EXISTS test_5cd13n3x 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032aa1b87 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a1ca94 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a2d4bd 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000349197cf 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000348953f8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:33:05.006317 [ 4745 ] {8ab30c6b-0126-41b8-9dc3-d24f87f56130} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '2bb15604e207:9000:bc43afb3-f96f-4f51-a0ea-56a3f0c3ec5d', current host ID: '2bb15604e207:9000:9ce8c158-8062-432f-9f4e-08f590746e84'. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000032aa1b87 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a1ca94 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a2d4bd 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000349197cf 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000348953f8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:06.173843 [ 3894 ] {42aa0023-6838-4d3e-9543-a05770d9ae2b} executeQuery: Code: 36. DB::Exception: Argument 1 must be DateTime or DateTime64, 'UInt8' given. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:58256) (comment: 02346_non_negative_derivative.sql) (in query: -- test against wrong arguments/types SELECT ts, metric, nonNegativeDerivative(metric, 1, INTERVAL 3 NANOSECOND) OVER (PARTITION BY metric ORDER BY ts, metric ASC Rows BETWEEN UNBOUNDED PRECEDING AND UNBOUNDED FOLLOWING) AS deriv FROM nnd;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, String&&) @ 0x000000000f947e4d 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2541: DB::NonNegativeDerivativeParams::NonNegativeDerivativeParams(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003ba89308 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2586: DB::WindowFunctionNonNegativeDerivative::WindowFunctionNonNegativeDerivative(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003ba8804b 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], String const&, std::vector, std::allocator>> const&, DB::Array const&, void>(std::allocator const&, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003ba87813 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000003ba44137 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306e2801 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 @ 0x00000000306dcf59 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3167: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a59ff 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 2025.10.23 23:33:06.174685 [ 3894 ] {42aa0023-6838-4d3e-9543-a05770d9ae2b} TCPHandler: Code: 36. DB::Exception: Argument 1 must be DateTime or DateTime64, 'UInt8' given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, String&&) @ 0x000000000f947e4d 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2541: DB::NonNegativeDerivativeParams::NonNegativeDerivativeParams(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003ba89308 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2586: DB::WindowFunctionNonNegativeDerivative::WindowFunctionNonNegativeDerivative(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003ba8804b 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], String const&, std::vector, std::allocator>> const&, DB::Array const&, void>(std::allocator const&, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003ba87813 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000003ba44137 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306e2801 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 @ 0x00000000306dcf59 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3167: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a59ff 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 2025.10.23 23:33:06.444577 [ 4636 ] {e6ba1755-035f-49ce-9263-0c97281d1c70} executeQuery: Code: 43. DB::Exception: Illegal types of arguments: Map(String, String), UInt8 for function arrayElement. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:58706) (comment: 02346_fulltext_index_bug52019.sql) (in query: SELECT * FROM tab PREWHERE (s[1]) = 'Click a03' SETTINGS enable_analyzer=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000861f137 4. DB::(anonymous namespace)::FunctionArrayElement::executeMap(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001eaab2b6 5. DB::(anonymous namespace)::FunctionArrayElement::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ea90204 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000003324d830 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000033248983 13. ./build_docker/./src/Processors/QueryPlan/SourceStepWithFilter.cpp:38: DB::SourceStepWithFilter::applyPrewhereActions(DB::Block, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000003c0f4d02 14. ./src/Core/Block.h:35: DB::MergeTreeSelectProcessor::transformHeader(DB::Block, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000039d3b737 15. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:284: DB::ReadFromMergeTree::ReadFromMergeTree(std::vector, std::allocator>>, std::shared_ptr, std::vector>, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr const&, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, std::shared_ptr, bool, std::optional>, std::optional (DB::ParallelReadRequest)>>, std::optional) @ 0x000000003bef423c 16. ./contrib/llvm-project/libcxx/include/optional:260: std::__unique_if::__unique_single std::make_unique[abi:v15007], std::allocator>>, std::shared_ptr, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&>(std::vector, std::allocator>>&&, std::shared_ptr&&, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&) @ 0x0000000039a7b01b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:928: DB::MergeTreeDataSelectExecutor::readFromParts(std::vector, std::allocator>>, std::shared_ptr, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, bool) const @ 0x0000000039a3e693 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:137: DB::MergeTreeDataSelectExecutor::read(std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, bool) const @ 0x0000000039a3dbd3 19. ./build_docker/./src/Storages/StorageMergeTree.cpp:249: DB::StorageMergeTree::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000003a2ef756 20. ./src/Processors/QueryPlan/QueryPlan.h:53: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000034d80c82 21. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1777: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d67094 22. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0b8de 23. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cfd8b2 24. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034cf6172 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5bf1 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 2025.10.23 23:33:06.445337 [ 4636 ] {e6ba1755-035f-49ce-9263-0c97281d1c70} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments: Map(String, String), UInt8 for function arrayElement. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000861f137 4. DB::(anonymous namespace)::FunctionArrayElement::executeMap(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001eaab2b6 5. DB::(anonymous namespace)::FunctionArrayElement::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ea90204 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000003324d830 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000033248983 13. ./build_docker/./src/Processors/QueryPlan/SourceStepWithFilter.cpp:38: DB::SourceStepWithFilter::applyPrewhereActions(DB::Block, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000003c0f4d02 14. ./src/Core/Block.h:35: DB::MergeTreeSelectProcessor::transformHeader(DB::Block, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000039d3b737 15. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:284: DB::ReadFromMergeTree::ReadFromMergeTree(std::vector, std::allocator>>, std::shared_ptr, std::vector>, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr const&, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, std::shared_ptr, bool, std::optional>, std::optional (DB::ParallelReadRequest)>>, std::optional) @ 0x000000003bef423c 16. ./contrib/llvm-project/libcxx/include/optional:260: std::__unique_if::__unique_single std::make_unique[abi:v15007], std::allocator>>, std::shared_ptr, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&>(std::vector, std::allocator>>&&, std::shared_ptr&&, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&) @ 0x0000000039a7b01b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:928: DB::MergeTreeDataSelectExecutor::readFromParts(std::vector, std::allocator>>, std::shared_ptr, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, bool) const @ 0x0000000039a3e693 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:137: DB::MergeTreeDataSelectExecutor::read(std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, bool) const @ 0x0000000039a3dbd3 19. ./build_docker/./src/Storages/StorageMergeTree.cpp:249: DB::StorageMergeTree::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000003a2ef756 20. ./src/Processors/QueryPlan/QueryPlan.h:53: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000034d80c82 21. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1777: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d67094 22. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0b8de 23. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cfd8b2 24. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034cf6172 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5bf1 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 2025.10.23 23:33:07.381158 [ 4752 ] {c7536661-d5bc-4623-80c0-31b110ff2913} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:52244) (comment: 02922_analyzer_aggregate_nothing_type.sql) (in query: SELECT quantileArray(0.5)([NULL, NULL]) AS x FROM remote('127.0.0.{1,2}', numbers(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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:33:07.390564 [ 4752 ] {c7536661-d5bc-4623-80c0-31b110ff2913} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:33:08.006689 [ 4745 ] {7a78ceb0-bda4-4b9b-95c2-387a26eae2e0} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44292) (comment: 02346_fulltext_index_bug52019.sql) (in query: DROP DATABASE IF EXISTS test_90k8zwus ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:33:08.008884 [ 4745 ] {7a78ceb0-bda4-4b9b-95c2-387a26eae2e0} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:08.021083 [ 2904 ] {ac479516-fce5-4f2c-ad24-3833c763bed0} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44344) (comment: 02346_fulltext_index_bug52019.sql) (in query: DROP DATABASE IF EXISTS test_90k8zwus ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:33:08.022306 [ 2904 ] {ac479516-fce5-4f2c-ad24-3833c763bed0} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:08.032975 [ 4712 ] {ac805b9c-0c1c-412f-bf11-06716589fc3f} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44350) (comment: 02346_fulltext_index_bug52019.sql) (in query: DROP DATABASE IF EXISTS test_90k8zwus ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:33:08.034073 [ 4712 ] {ac805b9c-0c1c-412f-bf11-06716589fc3f} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:08.050501 [ 4752 ] {97a3002e-8e08-4eca-b2a2-b87ccfb03430} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44364) (comment: 02346_fulltext_index_bug52019.sql) (in query: DROP DATABASE IF EXISTS test_90k8zwus ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:33:08.052657 [ 4752 ] {97a3002e-8e08-4eca-b2a2-b87ccfb03430} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:08.064079 [ 2904 ] {94b39c0d-c937-4923-8f82-406bb19dc4d2} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44370) (comment: 02346_fulltext_index_bug52019.sql) (in query: DROP DATABASE IF EXISTS test_90k8zwus ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:33:08.065289 [ 2904 ] {94b39c0d-c937-4923-8f82-406bb19dc4d2} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:08.680160 [ 4636 ] {a0b78dde-b682-42b9-a60d-207d24bb6f94} executeQuery: Code: 167. DB::Exception: AST is too deep. Maximum: 1000. (TOO_DEEP_AST) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:34480) (comment: 01196_max_parser_depth.sh) (in query: select coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, 1))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000a7e012a 4. ./build_docker/./src/Parsers/IAST.cpp:157: DB::IAST::checkDepthImpl(unsigned long) const @ 0x000000003d06fbaa 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x000000003d1b9439 6. ./build_docker/./src/Parsers/parseQuery.cpp:0: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003d1bccf0 7. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003d1bd031 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358ad0d2 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 10. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 11. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:33:08.682125 [ 4636 ] {a0b78dde-b682-42b9-a60d-207d24bb6f94} DynamicQueryHandler: Code: 167. DB::Exception: AST is too deep. Maximum: 1000. (TOO_DEEP_AST), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000a7e012a 4. ./build_docker/./src/Parsers/IAST.cpp:157: DB::IAST::checkDepthImpl(unsigned long) const @ 0x000000003d06fbaa 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x000000003d1b9439 6. ./build_docker/./src/Parsers/parseQuery.cpp:0: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003d1bccf0 7. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003d1bd031 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358ad0d2 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 10. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 11. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:08.754994 [ 4841 ] {599ceb0b-d5bb-4075-906a-1cdb26ae7463} 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]:50418). (NETWORK_ERROR) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:50418) (comment: 02922_analyzer_aggregate_nothing_type.sql) (in query: SELECT nothingNullArray(0.5)(_CAST([NULL, NULL], 'Array(Nullable(Nothing))')) AS `x` FROM numbers(3) 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c6938 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000003ac044bd 6. ./contrib/llvm-project/libcxx/include/__mutex_base:253: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfbb15 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 2025.10.23 23:33:08.946420 [ 4799 ] {c6ab2dd5-09ac-4dd7-a442-c75d74be62dd} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=734, jobs=712). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:52308) (comment: 02882_formatQuery.sql) (in query: SELECT formatQuery('EXPLAIN SYNTAX SELECT CAST(1 AS INT), CEIL(1), CEILING(1), CHAR(49), CHAR_LENGTH(\'1\'), CHARACTER_LENGTH(\'1\'), COALESCE(1), CONCAT(\'1\', \'1\'), CORR(1, 1), COS(1), COUNT(1), COVAR_POP(1, 1), COVAR_SAMP(1, 1), DATABASE(), SCHEMA(), DATEDIFF(\'DAY\', toDate(\'2020-10-24\'), toDate(\'2019-10-24\')), EXP(1), FLATTEN([[1]]), FLOOR(1), FQDN(), GREATEST(1), IF(1, 1, 1), IFNULL(1, 1), LCASE(\'A\'), LEAST(1), LENGTH(\'1\'), LN(1), LOCATE(\'1\', \'1\'), LOG(1), LOG10(1), LOG2(1), LOWER(\'A\'), MAX(1), MID(\'123\', 1, 1), MIN(1), MOD(1, 1), NOT(1), NOW(), NOW64(), NULLIF(1, 1), PI(), POSITION(\'123\', \'2\'), POW(1, 1), POWER(1, 1), RAND(), REPLACE(\'1\', \'1\', \'2\'), REVERSE(\'123\'), ROUND(1), SIN(1), SQRT(1), STDDEV_POP(1), STDDEV_SAMP(1), SUBSTR(\'123\', 2), SUBSTRING(\'123\', 2), SUM(1), TAN(1), TANH(1), TRUNC(1), TRUNCATE(1), UCASE(\'A\'), UPPER(\'A\'), USER(), VAR_POP(1), VAR_SAMP(1), WEEK(toDate(\'2020-10-24\')), YEARWEEK(toDate(\'2020-10-24\')) format TSVRaw;');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:33:08.947655 [ 4799 ] {c6ab2dd5-09ac-4dd7-a442-c75d74be62dd} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=734, jobs=712). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:33:09.094428 [ 3894 ] {7371dfc4-f7b7-4e89-9b5f-bcb96ef784c4} executeQuery: Code: 36. DB::Exception: Argument 0 must be a number, 'String' given. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:58256) (comment: 02346_non_negative_derivative.sql) (in query: SELECT ts, metric, nonNegativeDerivative('string not datetime', ts, INTERVAL 3 NANOSECOND) OVER (PARTITION BY metric ORDER BY ts, metric ASC Rows BETWEEN UNBOUNDED PRECEDING AND UNBOUNDED FOLLOWING) AS deriv FROM nnd;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, String&&) @ 0x000000000f947e4d 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2533: DB::NonNegativeDerivativeParams::NonNegativeDerivativeParams(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003ba88e25 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2586: DB::WindowFunctionNonNegativeDerivative::WindowFunctionNonNegativeDerivative(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003ba8804b 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], String const&, std::vector, std::allocator>> const&, DB::Array const&, void>(std::allocator const&, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003ba87813 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000003ba44137 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306e2801 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 @ 0x00000000306dcf59 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3167: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a59ff 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 2025.10.23 23:33:09.095929 [ 3894 ] {7371dfc4-f7b7-4e89-9b5f-bcb96ef784c4} TCPHandler: Code: 36. DB::Exception: Argument 0 must be a number, 'String' given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, String&&) @ 0x000000000f947e4d 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2533: DB::NonNegativeDerivativeParams::NonNegativeDerivativeParams(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003ba88e25 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2586: DB::WindowFunctionNonNegativeDerivative::WindowFunctionNonNegativeDerivative(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003ba8804b 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], String const&, std::vector, std::allocator>> const&, DB::Array const&, void>(std::allocator const&, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003ba87813 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000003ba44137 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306e2801 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 @ 0x00000000306dcf59 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3167: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a59ff 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 2025.10.23 23:33:09.171501 [ 4841 ] {599ceb0b-d5bb-4075-906a-1cdb26ae7463} 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]:50418). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c6938 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000003ac2dd9a 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x000000003abff96a 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9aa8 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:09.171949 [ 4841 ] {599ceb0b-d5bb-4075-906a-1cdb26ae7463} 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]:50418). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c6938 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000003ac044bd 6. ./contrib/llvm-project/libcxx/include/__mutex_base:253: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfbb15 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 2025.10.23 23:33:09.172504 [ 4841 ] {599ceb0b-d5bb-4075-906a-1cdb26ae7463} TCPHandler: Client has gone away. 2025.10.23 23:33:09.496440 [ 4636 ] {87085617-fd38-457b-afeb-4d936d90f326} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44396) (comment: 01049_join_low_card_crash.sql) (in query: DROP DATABASE IF EXISTS test_axd8318j ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:33:09.498805 [ 4636 ] {87085617-fd38-457b-afeb-4d936d90f326} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:10.222127 [ 4752 ] {b5900d7b-29c7-412f-8aaa-c14b2e87b17c} executeQuery: Code: 403. DB::Exception: Cannot determine join keys in RIGHT JOIN ... ON 1 = foo.b. (INVALID_JOIN_ON_EXPRESSION) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:52352) (comment: 01478_not_equi-join_on.sql) (in query: SELECT * FROM (SELECT NULL AS a, 1 AS b) AS foo RIGHT JOIN (SELECT 1024 AS b) AS bar ON 1 = foo.b;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:534: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034de50e9 5. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ddb4b5 6. ./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&) @ 0x0000000034d913d2 7. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d6a797 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0b8de 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cfd8b2 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034cf6172 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5bf1 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:33:10.222969 [ 4752 ] {b5900d7b-29c7-412f-8aaa-c14b2e87b17c} TCPHandler: Code: 403. DB::Exception: Cannot determine join keys in RIGHT JOIN ... ON 1 = foo.b. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:534: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034de50e9 5. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ddb4b5 6. ./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&) @ 0x0000000034d913d2 7. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d6a797 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0b8de 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cfd8b2 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034cf6172 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5bf1 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:33:10.275050 [ 4752 ] {8e67f9c2-ea5b-4b38-8594-4be38a183fd3} executeQuery: Code: 403. DB::Exception: Cannot determine join keys in RIGHT JOIN ... ON 1 = bar.b. (INVALID_JOIN_ON_EXPRESSION) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:52352) (comment: 01478_not_equi-join_on.sql) (in query: SELECT * FROM (SELECT NULL AS a, 1 AS b) AS foo RIGHT JOIN (SELECT 1024 AS b) AS bar ON 1 = bar.b;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:534: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034de50e9 5. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ddb4b5 6. ./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&) @ 0x0000000034d913d2 7. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d6a797 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0b8de 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cfd8b2 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034cf6172 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5bf1 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:33:10.275804 [ 4752 ] {8e67f9c2-ea5b-4b38-8594-4be38a183fd3} TCPHandler: Code: 403. DB::Exception: Cannot determine join keys in RIGHT JOIN ... ON 1 = bar.b. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:534: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000034de50e9 5. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ddb4b5 6. ./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&) @ 0x0000000034d913d2 7. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d6a797 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0b8de 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cfd8b2 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034cf6172 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5bf1 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:33:10.452548 [ 3895 ] {08440bf7-daea-4800-8893-082f0ead25b6} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=4, jobs=3): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:52322) (comment: 02565_update_empty_nested.sql) (in query: SELECT * FROM t_update_empty_nested 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000039d07892 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&) @ 0x0000000039d09d4a 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:63: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x00000000326402a2 12. ./build_docker/./src/DataTypes/Serializations/SerializationNamed.cpp:0: DB::SerializationNamed::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000003276d0e1 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:63: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000003266443d 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000032640cad 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000039d01224 16. ./contrib/llvm-project/libcxx/include/vector:547: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000039d00b49 17. ./contrib/llvm-project/libcxx/include/__tree:1088: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) @ 0x00000000399bb1c8 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 @ 0x00000000399b0254 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039d45fb0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003bfd663a 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c083c53 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003bfe2b53 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d3c440 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf89b85 25. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 26. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 30. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 31. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 2025.10.23 23:33:10.454196 [ 3895 ] {08440bf7-daea-4800-8893-082f0ead25b6} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=4, 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000039d07892 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&) @ 0x0000000039d09d4a 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:63: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x00000000326402a2 12. ./build_docker/./src/DataTypes/Serializations/SerializationNamed.cpp:0: DB::SerializationNamed::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000003276d0e1 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:63: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000003266443d 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000032640cad 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000039d01224 16. ./contrib/llvm-project/libcxx/include/vector:547: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000039d00b49 17. ./contrib/llvm-project/libcxx/include/__tree:1088: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) @ 0x00000000399bb1c8 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 @ 0x00000000399b0254 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039d45fb0 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003bfd663a 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c083c53 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003bfe2b53 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d3c440 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf89b85 25. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 26. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 30. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 31. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 2025.10.23 23:33:10.663058 [ 4752 ] {6041bdf3-7989-423c-b1c1-54e8a3cabac3} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44448) (comment: 02565_update_empty_nested.sql) (in query: DROP DATABASE IF EXISTS test_u9kfouvg ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:33:10.665057 [ 4752 ] {6041bdf3-7989-423c-b1c1-54e8a3cabac3} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:12.151245 [ 3894 ] {5d38d3ed-e983-4ecc-a30b-d856efc19aaa} executeQuery: Code: 42. DB::Exception: Function nonNegativeDerivative takes 2 or 3 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:58256) (comment: 02346_non_negative_derivative.sql) (in query: SELECT ts, metric, nonNegativeDerivative(metric, ts, INTERVAL 3 NANOSECOND, id) OVER (PARTITION BY metric ORDER BY ts, metric ASC Rows BETWEEN UNBOUNDED PRECEDING AND UNBOUNDED FOLLOWING) AS deriv FROM nnd;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2527: DB::NonNegativeDerivativeParams::NonNegativeDerivativeParams(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003ba88a37 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2586: DB::WindowFunctionNonNegativeDerivative::WindowFunctionNonNegativeDerivative(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003ba8804b 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], String const&, std::vector, std::allocator>> const&, DB::Array const&, void>(std::allocator const&, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003ba87813 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000003ba44137 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306e2801 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 @ 0x00000000306dcf59 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3167: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a59ff 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 2025.10.23 23:33:12.152205 [ 3894 ] {5d38d3ed-e983-4ecc-a30b-d856efc19aaa} TCPHandler: Code: 42. DB::Exception: Function nonNegativeDerivative takes 2 or 3 arguments. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2527: DB::NonNegativeDerivativeParams::NonNegativeDerivativeParams(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003ba88a37 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2586: DB::WindowFunctionNonNegativeDerivative::WindowFunctionNonNegativeDerivative(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003ba8804b 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], String const&, std::vector, std::allocator>> const&, DB::Array const&, void>(std::allocator const&, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003ba87813 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000003ba44137 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306e2801 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 @ 0x00000000306dcf59 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3167: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a59ff 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 2025.10.23 23:33:12.166791 [ 3894 ] {d6b6a044-f866-4c41-941b-51a58a9469a7} executeQuery: Code: 42. DB::Exception: Function nonNegativeDerivative takes 2 or 3 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:58256) (comment: 02346_non_negative_derivative.sql) (in query: SELECT ts, metric, nonNegativeDerivative(metric) OVER (PARTITION BY metric ORDER BY ts, metric ASC Rows BETWEEN UNBOUNDED PRECEDING AND UNBOUNDED FOLLOWING) AS deriv FROM nnd;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2527: DB::NonNegativeDerivativeParams::NonNegativeDerivativeParams(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003ba88a37 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2586: DB::WindowFunctionNonNegativeDerivative::WindowFunctionNonNegativeDerivative(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003ba8804b 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], String const&, std::vector, std::allocator>> const&, DB::Array const&, void>(std::allocator const&, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003ba87813 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000003ba44137 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306e2801 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 @ 0x00000000306dcf59 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3167: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a59ff 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 2025.10.23 23:33:12.167556 [ 3894 ] {d6b6a044-f866-4c41-941b-51a58a9469a7} TCPHandler: Code: 42. DB::Exception: Function nonNegativeDerivative takes 2 or 3 arguments. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2527: DB::NonNegativeDerivativeParams::NonNegativeDerivativeParams(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003ba88a37 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2586: DB::WindowFunctionNonNegativeDerivative::WindowFunctionNonNegativeDerivative(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003ba8804b 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], String const&, std::vector, std::allocator>> const&, DB::Array const&, void>(std::allocator const&, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003ba87813 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000003ba44137 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306e2801 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 @ 0x00000000306dcf59 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3167: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a59ff 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 2025.10.23 23:33:12.758285 [ 4752 ] {d0f5daeb-b940-477b-807c-cc4e1bf79a43} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:52384) (comment: 03093_analyzer_miel_test.sql) (in query: select app, arrayZip(untuple(sumMap(k.keys, replicate(1, k.keys)))) from test_03093 PREWHERE c > 1 group by app;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202dea34 6. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039a5dbc5 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003bf2b229 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bf26bba 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003bf26345 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bf3d5b9 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2045: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf42fe0 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be48783 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003beb6da5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034cf5e6d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034cf5881 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:33:12.759932 [ 4752 ] {d0f5daeb-b940-477b-807c-cc4e1bf79a43} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202dea34 6. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039a5dbc5 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003bf2b229 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bf26bba 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003bf26345 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bf3d5b9 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2045: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf42fe0 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be48783 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003beb6da5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034cf5e6d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034cf5881 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:33:18.991891 [ 3769 ] {} virtual void DB::SystemLog::savingThreadFunction() [LogElement = DB::ObjectStorageQueueLogElement]: 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x0000000039709f85 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>) @ 0x000000003a2e5f4a 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a2e404f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2d3063 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7b27a 12. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x0000000038308626 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348e414c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 16. ./build_docker/./src/Interpreters/SystemLog.cpp:0: DB::SystemLog::prepareTable() @ 0x000000003540b708 17. ./build_docker/./src/Interpreters/SystemLog.cpp:0: DB::SystemLog::savingThreadFunction() @ 0x000000003540f82d 18. ./build_docker/./src/Common/SystemLogBase.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl::startup()::'lambda'()>(DB::SystemLogBase::startup()::'lambda'()&&)::'lambda'()::operator()() @ 0x00000000203d9201 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000203d903f 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 22. ? @ 0x00007f100c857ac3 23. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:20.201689 [ 4712 ] {9d336c0a-df71-4a16-b7f4-dc327699f79c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=734, jobs=713). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:50484) (comment: 02345_analyzer_subqueries.sql) (in query: WITH subquery AS (SELECT 1 AS a) SELECT subquery.a FROM subquery;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:33:20.210956 [ 4712 ] {9d336c0a-df71-4a16-b7f4-dc327699f79c} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=734, jobs=713). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:33:22.085002 [ 4713 ] {5c125be9-f368-4057-9708-5f2a5010d6d7} DatabaseReplicated (test_11): It's not recommended to explicitly specify zookeeper_path and replica_name in ReplicatedMergeTree arguments 2025.10.23 23:33:22.086017 [ 4713 ] {5c125be9-f368-4057-9708-5f2a5010d6d7} executeQuery: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:50658) (comment: 02446_parent_zero_copy_locks.sql) (in query: CREATE TABLE rmt1 (`n` int, `m` int, `k` int) ENGINE = ReplicatedMergeTree('/test/02446/{database}/rmt', '1') ORDER BY n SETTINGS storage_policy = 's3_cache', allow_remote_fs_zero_copy_replication = 1, old_parts_lifetime = 0, cleanup_delay_period = 0, max_cleanup_delay_period = 1, cleanup_delay_period_random_add = 1, min_bytes_for_wide_part = 0, index_granularity = 33082, 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 = 115082509, compact_parts_max_bytes_to_buffer = 170908825, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 25983237, merge_max_block_size = 8211, prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 41, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 11865032, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 96634, primary_key_compress_block_size = 69464), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000032a4a38c 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000032a4fcff 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a51799 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfab2 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:33:22.087115 [ 4713 ] {5c125be9-f368-4057-9708-5f2a5010d6d7} TCPHandler: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000032a4a38c 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000032a4fcff 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a51799 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfab2 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:33:22.235357 [ 3895 ] {f7f53d0d-930f-46f1-8c53-ebdce8ab6bd7} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:50588). (NETWORK_ERROR) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:50588) (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c6938 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000003ac044bd 6. ./contrib/llvm-project/libcxx/include/__mutex_base:253: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfbb15 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 2025.10.23 23:33:22.344933 [ 3895 ] {f7f53d0d-930f-46f1-8c53-ebdce8ab6bd7} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:50588). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c6938 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000003ac044bd 6. ./contrib/llvm-project/libcxx/include/__mutex_base:253: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfbb15 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 2025.10.23 23:33:22.345473 [ 3895 ] {f7f53d0d-930f-46f1-8c53-ebdce8ab6bd7} TCPHandler: Client has gone away. 2025.10.23 23:33:22.906109 [ 4636 ] {282970b5-4232-4895-a6a8-d0d6db8a7b6d} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Merge. (NOT_IMPLEMENTED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:50646) (comment: 02111_modify_table_comment.sql) (in query: DROP DATABASE 02111_modify_table_comment;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000002ffc5e67 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003493f2d5 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>>>&) @ 0x0000000034947b8d 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:33:22.907616 [ 4636 ] {282970b5-4232-4895-a6a8-d0d6db8a7b6d} TCPHandler: Code: 48. DB::Exception: Truncate is not supported by storage Merge. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000002ffc5e67 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003493f2d5 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>>>&) @ 0x0000000034947b8d 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:33:23.376087 [ 4713 ] {097b9bde-f8cc-4d30-afe9-3edf4944ca99} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:50724) (comment: 00815_left_join_on_stepanel.sql) (in query: DROP DATABASE test_1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:33:23.378016 [ 4713 ] {097b9bde-f8cc-4d30-afe9-3edf4944ca99} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:33:23.774369 [ 4713 ] {9ce9e57e-4856-450c-8fe2-4035688dc3c7} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=734, jobs=713). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:50766) (comment: 00580_consistent_hashing_functions.sql) (in query: SELECT kostikConsistentHash(16045690984833335023, 1), kostikConsistentHash(16045690984833335023, 2), kostikConsistentHash(16045690984833335023, 3), kostikConsistentHash(16045690984833335023, 4), kostikConsistentHash(16045690984833335023, 173), kostikConsistentHash(16045690984833335023, 255);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:33:23.776956 [ 4713 ] {9ce9e57e-4856-450c-8fe2-4035688dc3c7} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=734, jobs=713). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:33:24.022117 [ 4713 ] {08870aca-da06-434b-9996-4bb43d1cdc81} executeQuery: Code: 57. DB::Exception: Table test_1.fact_cpc_clicks already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:50794) (comment: 00815_left_join_on_stepanel.sql) (in query: CREATE TABLE fact_cpc_clicks (model_id UInt8) 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:33:24.024443 [ 4713 ] {08870aca-da06-434b-9996-4bb43d1cdc81} TCPHandler: Code: 57. DB::Exception: Table test_1.fact_cpc_clicks already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:33:24.543074 [ 2904 ] {57bf9bdc-fb71-4947-9076-deb9a0c7bee5} executeQuery: Code: 36. DB::Exception: Path of the custom local disk must be inside `/var/lib/clickhouse/disks/` directory: While processing disk(type = local, path = '/local/'). (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02454_create_table_with_custom_disk.sql) (in query: /* ddl_entry=query-0000000008 */ CREATE TABLE test_11.test UUID '91263ffc-72ad-47f3-821e-840ea8a56e51' (`a` Int32) ENGINE = MergeTree ORDER BY tuple() SETTINGS disk = disk(type = local, path = '/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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000842350a 4. ./build_docker/./src/Disks/DiskFomAST.cpp:0: DB::getOrCreateCustomDisk(Poco::AutoPtr, String const&, std::shared_ptr, bool) @ 0x0000000039e01dfd 5. ./base/poco/Foundation/include/Poco/AutoPtr.h:90: DB::DiskConfigurationFlattener::visit(std::shared_ptr&, DB::DiskConfigurationFlattener::Data&) @ 0x0000000039e051c1 6. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x0000000039e04bb5 7. ./build_docker/./src/Disks/DiskFomAST.cpp:135: DB::DiskFomAST::createCustomDisk(std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000039e02928 8. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:0: DB::MergeTreeSettings::loadFromQuery(DB::ASTStorage&, std::shared_ptr, bool) @ 0x0000000039d9a66f 9. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:729: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2d01bf 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7b27a 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 @ 0x0000000038308626 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348e414c 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003395fc9e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000033958fac 19. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ad726d 20. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a52a3c 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfab2 22. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 2025.10.23 23:33:24.549761 [ 2904 ] {57bf9bdc-fb71-4947-9076-deb9a0c7bee5} executeQuery: Code: 36. DB::Exception: Path of the custom local disk must be inside `/var/lib/clickhouse/disks/` directory: While processing disk(type = local, path = '/local/'). (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:50696) (comment: 02454_create_table_with_custom_disk.sql) (in query: CREATE TABLE test (a Int32) ENGINE = MergeTree() order by tuple() SETTINGS disk = disk(type=local, path='/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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000842350a 4. ./build_docker/./src/Disks/DiskFomAST.cpp:0: DB::getOrCreateCustomDisk(Poco::AutoPtr, String const&, std::shared_ptr, bool) @ 0x0000000039e01dfd 5. ./base/poco/Foundation/include/Poco/AutoPtr.h:90: DB::DiskConfigurationFlattener::visit(std::shared_ptr&, DB::DiskConfigurationFlattener::Data&) @ 0x0000000039e051c1 6. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x0000000039e04bb5 7. ./build_docker/./src/Disks/DiskFomAST.cpp:135: DB::DiskFomAST::createCustomDisk(std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000039e02928 8. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:0: DB::MergeTreeSettings::loadFromQuery(DB::ASTStorage&, std::shared_ptr, bool) @ 0x0000000039d9a66f 9. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:729: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2d01bf 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7b27a 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 @ 0x0000000038308626 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348e414c 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003395fc9e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000033958fac 19. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ad726d 20. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a52a3c 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfab2 22. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 2025.10.23 23:33:24.550715 [ 2904 ] {57bf9bdc-fb71-4947-9076-deb9a0c7bee5} TCPHandler: Code: 36. DB::Exception: Path of the custom local disk must be inside `/var/lib/clickhouse/disks/` directory: While processing disk(type = local, path = '/local/'). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000842350a 4. ./build_docker/./src/Disks/DiskFomAST.cpp:0: DB::getOrCreateCustomDisk(Poco::AutoPtr, String const&, std::shared_ptr, bool) @ 0x0000000039e01dfd 5. ./base/poco/Foundation/include/Poco/AutoPtr.h:90: DB::DiskConfigurationFlattener::visit(std::shared_ptr&, DB::DiskConfigurationFlattener::Data&) @ 0x0000000039e051c1 6. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x0000000039e04bb5 7. ./build_docker/./src/Disks/DiskFomAST.cpp:135: DB::DiskFomAST::createCustomDisk(std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000039e02928 8. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:0: DB::MergeTreeSettings::loadFromQuery(DB::ASTStorage&, std::shared_ptr, bool) @ 0x0000000039d9a66f 9. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:729: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2d01bf 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7b27a 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 @ 0x0000000038308626 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348e414c 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003395fc9e 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000033958fac 19. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ad726d 20. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a52a3c 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfab2 22. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 2025.10.23 23:33:25.988472 [ 2904 ] {63333fcc-3976-4b7e-98e0-abe357d6cc9e} 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.10542.altinitytest (altinity build)) (from [::1]:50696) (comment: 02454_create_table_with_custom_disk.sql) (in query: DETACH 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:979: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000032a50c33 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a51799 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:222: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003493e6e9 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:33:25.989175 [ 2904 ] {63333fcc-3976-4b7e-98e0-abe357d6cc9e} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:979: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000032a50c33 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a51799 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:222: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003493e6e9 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:33:27.088488 [ 3895 ] {9d3b5ee2-8af0-48ef-a6a7-4a4997fb346f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=734, jobs=713). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:47934) (comment: 02766_connection_string.sh) (in query: SELECT 34), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:33:27.089993 [ 3895 ] {9d3b5ee2-8af0-48ef-a6a7-4a4997fb346f} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=734, jobs=713). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:33:27.943273 [ 4713 ] {c09500be-3a18-4889-962b-c2aa775b5b4d} executeQuery: Code: 41. DB::Exception: Cannot read DateTime: unexpected date: 2025-2-55: In scope SELECT parseDateTime64BestEffort('2.55'). (CANNOT_PARSE_DATETIME) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:47832) (comment: 01424_parse_date_time_bad_date.sql) (in query: select parseDateTime64BestEffort('2.55');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned short&, unsigned short&&, unsigned short&&) @ 0x0000000020274017 4. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:0: DB::parseDateTime64BestEffort(DB::DateTime64&, unsigned int, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&) @ 0x0000000020242878 5. DB::(anonymous namespace)::FunctionConvertFromString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009562619 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 2025.10.23 23:33:27.944430 [ 4713 ] {c09500be-3a18-4889-962b-c2aa775b5b4d} TCPHandler: Code: 41. DB::Exception: Cannot read DateTime: unexpected date: 2025-2-55: In scope SELECT parseDateTime64BestEffort('2.55'). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned short&, unsigned short&&, unsigned short&&) @ 0x0000000020274017 4. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:0: DB::parseDateTime64BestEffort(DB::DateTime64&, unsigned int, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&) @ 0x0000000020242878 5. DB::(anonymous namespace)::FunctionConvertFromString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009562619 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 2025.10.23 23:33:28.277879 [ 4752 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:47954, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x00000000204bfd30 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x00000000204c0cc1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a8112cd 6. DB::ReadBuffer::next() @ 0x00000000095b468f 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000003abd729e 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:28.409292 [ 3894 ] {7eadd8f4-8d58-4309-b834-b74985a7cca2} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48018) (comment: 01116_cross_count_asterisks.sql) (in query: SELECT count(*) FROM numbers(2) AS n1, numbers(3) AS n2, numbers(4) AS n3 WHERE (n1.number = n2.number) AND (n2.number = n3.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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:33:28.416057 [ 3894 ] {7eadd8f4-8d58-4309-b834-b74985a7cca2} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:33:28.693328 [ 4713 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:47990, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x00000000204bfd30 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x00000000204c0cc1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a8112cd 6. DB::ReadBuffer::next() @ 0x00000000095b468f 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000003abd729e 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:29.261281 [ 4745 ] {d2892337-f7ed-42f5-9e3b-8f5f858ec7b7} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=734, jobs=713). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48048) (comment: 01837_cast_to_array_from_empty_array.sql) (in query: SELECT CAST([] AS Array(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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:33:29.263622 [ 4745 ] {d2892337-f7ed-42f5-9e3b-8f5f858ec7b7} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=734, jobs=713). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:33:29.377994 [ 2904 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:48044, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x00000000204bfd30 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x00000000204c0cc1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a8112cd 6. DB::ReadBuffer::next() @ 0x00000000095b468f 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000003abd729e 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:29.576546 [ 4712 ] {d3e03c34-62f9-4204-bb77-172d8b47ae7a} executeQuery: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 64.00 GiB (attempt to allocate chunk of 68720001024 bytes), maximum: 9.31 GiB.: While executing GenerateRandom. (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48030) (comment: 01529_bad_memory_tracking.sh) (in query: SELECT i FROM generateRandom('i Array(Int8)', 1, 1, 1048577) LIMIT 65536), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000002009bbd0 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099e92 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099272 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7ca1d 7. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ff775a4 8. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x00000000083abe10 9. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:64: DB::(anonymous namespace)::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x00000000383ca9b6 10. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:0: DB::(anonymous namespace)::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x00000000383cff00 11. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:0: DB::(anonymous namespace)::GenerateSource::generate() @ 0x00000000383c77d3 12. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae71153 13. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 22. ? @ 0x00007f100c857ac3 23. ? @ 0x00007f100c8e9850 2025.10.23 23:33:29.578413 [ 4712 ] {d3e03c34-62f9-4204-bb77-172d8b47ae7a} TCPHandler: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 64.00 GiB (attempt to allocate chunk of 68720001024 bytes), maximum: 9.31 GiB.: While executing GenerateRandom. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000002009bbd0 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099e92 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099272 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7ca1d 7. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ff775a4 8. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x00000000083abe10 9. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:64: DB::(anonymous namespace)::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x00000000383ca9b6 10. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:0: DB::(anonymous namespace)::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x00000000383cff00 11. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:0: DB::(anonymous namespace)::GenerateSource::generate() @ 0x00000000383c77d3 12. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae71153 13. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 22. ? @ 0x00007f100c857ac3 23. ? @ 0x00007f100c8e9850 2025.10.23 23:33:30.065634 [ 2904 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:48080, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x00000000204bfd30 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x00000000204c0cc1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a8112cd 6. DB::ReadBuffer::next() @ 0x00000000095b468f 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000003abd729e 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:30.202093 [ 4712 ] {0be4b35e-62a0-4572-8bac-97b6ab5075e0} executeQuery: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 96.00 GiB (attempt to allocate chunk of 68720001024 bytes), maximum: 9.31 GiB.: While executing GenerateRandom. (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48090) (comment: 01529_bad_memory_tracking.sh) (in query: SELECT i FROM generateRandom('i Array(Int8)', 1, 1, 1048577) LIMIT 65536), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000002009bbd0 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099e92 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099272 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7ca1d 7. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ff775a4 8. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x00000000083abe10 9. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:64: DB::(anonymous namespace)::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x00000000383ca9b6 10. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:0: DB::(anonymous namespace)::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x00000000383cff00 11. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:0: DB::(anonymous namespace)::GenerateSource::generate() @ 0x00000000383c77d3 12. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae71153 13. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 22. ? @ 0x00007f100c857ac3 23. ? @ 0x00007f100c8e9850 2025.10.23 23:33:30.203346 [ 4712 ] {0be4b35e-62a0-4572-8bac-97b6ab5075e0} TCPHandler: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 96.00 GiB (attempt to allocate chunk of 68720001024 bytes), maximum: 9.31 GiB.: While executing GenerateRandom. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000002009bbd0 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099e92 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099272 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7ca1d 7. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ff775a4 8. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x00000000083abe10 9. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:64: DB::(anonymous namespace)::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x00000000383ca9b6 10. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:0: DB::(anonymous namespace)::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x00000000383cff00 11. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:0: DB::(anonymous namespace)::GenerateSource::generate() @ 0x00000000383c77d3 12. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae71153 13. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 22. ? @ 0x00007f100c857ac3 23. ? @ 0x00007f100c8e9850 2025.10.23 23:33:30.795247 [ 4712 ] {ceaa9fb8-c656-43a7-8397-6ca73704c4eb} executeQuery: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 64.00 GiB (attempt to allocate chunk of 68720001024 bytes), maximum: 9.31 GiB.: While executing GenerateRandom. (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48136) (comment: 01529_bad_memory_tracking.sh) (in query: SELECT i FROM generateRandom('i Array(Int8)', 1, 1, 1048577) LIMIT 65536), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000002009bbd0 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099e92 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099272 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7ca1d 7. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ff775a4 8. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x00000000083abe10 9. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:64: DB::(anonymous namespace)::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x00000000383ca9b6 10. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:0: DB::(anonymous namespace)::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x00000000383cff00 11. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:0: DB::(anonymous namespace)::GenerateSource::generate() @ 0x00000000383c77d3 12. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae71153 13. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 22. ? @ 0x00007f100c857ac3 23. ? @ 0x00007f100c8e9850 2025.10.23 23:33:30.796661 [ 4712 ] {ceaa9fb8-c656-43a7-8397-6ca73704c4eb} TCPHandler: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 64.00 GiB (attempt to allocate chunk of 68720001024 bytes), maximum: 9.31 GiB.: While executing GenerateRandom. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000002009bbd0 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099e92 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099272 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7ca1d 7. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ff775a4 8. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x00000000083abe10 9. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:64: DB::(anonymous namespace)::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x00000000383ca9b6 10. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:0: DB::(anonymous namespace)::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x00000000383cff00 11. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:0: DB::(anonymous namespace)::GenerateSource::generate() @ 0x00000000383c77d3 12. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae71153 13. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 22. ? @ 0x00007f100c857ac3 23. ? @ 0x00007f100c8e9850 2025.10.23 23:33:31.463019 [ 4745 ] {99118d0c-1d1e-47ae-9c8c-35d55ed2b7ce} executeQuery: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 64.00 GiB (attempt to allocate chunk of 68720001024 bytes), maximum: 9.31 GiB.: While executing GenerateRandom. (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48190) (comment: 01529_bad_memory_tracking.sh) (in query: SELECT i FROM generateRandom('i Array(Int8)', 1, 1, 1048577) LIMIT 65536), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000002009bbd0 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099e92 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099272 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7ca1d 7. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ff775a4 8. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x00000000083abe10 9. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:64: DB::(anonymous namespace)::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x00000000383ca9b6 10. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:0: DB::(anonymous namespace)::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x00000000383cff00 11. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:0: DB::(anonymous namespace)::GenerateSource::generate() @ 0x00000000383c77d3 12. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae71153 13. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 22. ? @ 0x00007f100c857ac3 23. ? @ 0x00007f100c8e9850 2025.10.23 23:33:31.464946 [ 4745 ] {99118d0c-1d1e-47ae-9c8c-35d55ed2b7ce} TCPHandler: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 64.00 GiB (attempt to allocate chunk of 68720001024 bytes), maximum: 9.31 GiB.: While executing GenerateRandom. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000002009bbd0 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099e92 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099272 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7ca1d 7. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ff775a4 8. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x00000000083abe10 9. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:64: DB::(anonymous namespace)::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x00000000383ca9b6 10. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:0: DB::(anonymous namespace)::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x00000000383cff00 11. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:0: DB::(anonymous namespace)::GenerateSource::generate() @ 0x00000000383c77d3 12. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae71153 13. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 22. ? @ 0x00007f100c857ac3 23. ? @ 0x00007f100c8e9850 2025.10.23 23:33:31.867330 [ 4070 ] {cb99a6e3-0610-41a2-8c94-7bac88650792} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=734, jobs=714). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:51356) (comment: 00653_verification_monotonic_data_load.sh) (in query: SELECT count() AS `count()` FROM `test_15`.`signed_integer_test_table` AS `__table1` WHERE toInt16(`__table1`.`val`) = 0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:33:31.869154 [ 4070 ] {cb99a6e3-0610-41a2-8c94-7bac88650792} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=734, jobs=714). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:33:31.901863 [ 4675 ] {720ca907-1a16-4894-9102-53a604d90639} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=734, jobs=713). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:39560) (comment: 00653_verification_monotonic_data_load.sh) (in query: SELECT count() AS `count()` FROM `test_15`.`signed_integer_test_table` AS `__table1` WHERE toInt16(`__table1`.`val`) = 0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:33:31.903648 [ 4675 ] {720ca907-1a16-4894-9102-53a604d90639} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=734, jobs=713). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:33:32.047543 [ 4799 ] {3d09f739-f449-4e7c-b074-1f4a32967557} executeQuery: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 64.00 GiB (attempt to allocate chunk of 68720001024 bytes), maximum: 9.31 GiB.: While executing GenerateRandom. (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48230) (comment: 01529_bad_memory_tracking.sh) (in query: SELECT i FROM generateRandom('i Array(Int8)', 1, 1, 1048577) LIMIT 65536), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000002009bbd0 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099e92 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099272 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7ca1d 7. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ff775a4 8. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x00000000083abe10 9. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:64: DB::(anonymous namespace)::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x00000000383ca9b6 10. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:0: DB::(anonymous namespace)::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x00000000383cff00 11. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:0: DB::(anonymous namespace)::GenerateSource::generate() @ 0x00000000383c77d3 12. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae71153 13. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 22. ? @ 0x00007f100c857ac3 23. ? @ 0x00007f100c8e9850 2025.10.23 23:33:32.048753 [ 4799 ] {3d09f739-f449-4e7c-b074-1f4a32967557} TCPHandler: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 64.00 GiB (attempt to allocate chunk of 68720001024 bytes), maximum: 9.31 GiB.: While executing GenerateRandom. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000002009bbd0 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099e92 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099272 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7ca1d 7. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ff775a4 8. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x00000000083abe10 9. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:64: DB::(anonymous namespace)::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x00000000383ca9b6 10. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:0: DB::(anonymous namespace)::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x00000000383cff00 11. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:0: DB::(anonymous namespace)::GenerateSource::generate() @ 0x00000000383c77d3 12. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae71153 13. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 22. ? @ 0x00007f100c857ac3 23. ? @ 0x00007f100c8e9850 2025.10.23 23:33:32.545116 [ 4745 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:48240, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x00000000204bfd30 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x00000000204c0cc1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a8112cd 6. DB::ReadBuffer::next() @ 0x00000000095b468f 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000003abd729e 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:32.658661 [ 2904 ] {2261693d-0747-47db-a184-07a589dcec4e} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.5:9000. DB::Exception: Cannot schedule a task: fault injected (threads=734, jobs=714). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48214) (comment: 00653_verification_monotonic_data_load.sh) (in query: SELECT count() FROM signed_integer_test_table WHERE toInt16(val) == 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002019af32 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000003a7e3e0c 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::Connection::receivePacket() @ 0x000000003a7ff61b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:340: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003a8df9b9 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:0: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000032358b71 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000323566d1 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032355a26 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000032352f12 2025.10.23 23:33:32.660707 [ 4675 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:39560, local: [::ffff:127.0.0.7]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x00000000204bfd30 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x00000000204c0cc1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a8112cd 6. DB::ReadBuffer::next() @ 0x00000000095b468f 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000003abd729e 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:32.662634 [ 2904 ] {2261693d-0747-47db-a184-07a589dcec4e} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.5:9000. DB::Exception: Cannot schedule a task: fault injected (threads=734, jobs=714). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 : 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002019af32 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000003a7e3e0c 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::Connection::receivePacket() @ 0x000000003a7ff61b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:340: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003a8df9b9 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:0: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000032358b71 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000323566d1 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032355a26 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000032352f12 2025.10.23 23:33:32.663082 [ 2904 ] {2261693d-0747-47db-a184-07a589dcec4e} TCPHandler: Client has gone away. 2025.10.23 23:33:32.675446 [ 4745 ] {0dfb0071-3a2d-4387-87a3-383fb219789f} executeQuery: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 64.00 GiB (attempt to allocate chunk of 68720001024 bytes), maximum: 9.31 GiB.: While executing GenerateRandom. (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48260) (comment: 01529_bad_memory_tracking.sh) (in query: SELECT i FROM generateRandom('i Array(Int8)', 1, 1, 1048577) LIMIT 65536), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000002009bbd0 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099e92 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099272 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7ca1d 7. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ff775a4 8. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x00000000083abe10 9. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:64: DB::(anonymous namespace)::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x00000000383ca9b6 10. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:0: DB::(anonymous namespace)::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x00000000383cff00 11. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:0: DB::(anonymous namespace)::GenerateSource::generate() @ 0x00000000383c77d3 12. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae71153 13. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 22. ? @ 0x00007f100c857ac3 23. ? @ 0x00007f100c8e9850 2025.10.23 23:33:32.676737 [ 4745 ] {0dfb0071-3a2d-4387-87a3-383fb219789f} TCPHandler: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 64.00 GiB (attempt to allocate chunk of 68720001024 bytes), maximum: 9.31 GiB.: While executing GenerateRandom. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000002009bbd0 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099e92 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099272 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7ca1d 7. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ff775a4 8. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x00000000083abe10 9. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:64: DB::(anonymous namespace)::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x00000000383ca9b6 10. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:0: DB::(anonymous namespace)::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x00000000383cff00 11. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:0: DB::(anonymous namespace)::GenerateSource::generate() @ 0x00000000383c77d3 12. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae71153 13. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 22. ? @ 0x00007f100c857ac3 23. ? @ 0x00007f100c8e9850 2025.10.23 23:33:33.259274 [ 4636 ] {e1a46f36-7795-4f6c-916a-6d2af160c1b7} executeQuery: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 64.00 GiB (attempt to allocate chunk of 68720001024 bytes), maximum: 9.31 GiB.: While executing GenerateRandom. (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48272) (comment: 01529_bad_memory_tracking.sh) (in query: SELECT i FROM generateRandom('i Array(Int8)', 1, 1, 1048577) LIMIT 65536), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000002009bbd0 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099e92 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099272 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7ca1d 7. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ff775a4 8. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x00000000083abe10 9. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:64: DB::(anonymous namespace)::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x00000000383ca9b6 10. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:0: DB::(anonymous namespace)::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x00000000383cff00 11. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:0: DB::(anonymous namespace)::GenerateSource::generate() @ 0x00000000383c77d3 12. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae71153 13. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 22. ? @ 0x00007f100c857ac3 23. ? @ 0x00007f100c8e9850 2025.10.23 23:33:33.260976 [ 4636 ] {e1a46f36-7795-4f6c-916a-6d2af160c1b7} TCPHandler: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 64.00 GiB (attempt to allocate chunk of 68720001024 bytes), maximum: 9.31 GiB.: While executing GenerateRandom. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000002009bbd0 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099e92 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099272 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7ca1d 7. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ff775a4 8. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x00000000083abe10 9. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:64: DB::(anonymous namespace)::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x00000000383ca9b6 10. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:0: DB::(anonymous namespace)::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x00000000383cff00 11. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:0: DB::(anonymous namespace)::GenerateSource::generate() @ 0x00000000383c77d3 12. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae71153 13. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 22. ? @ 0x00007f100c857ac3 23. ? @ 0x00007f100c8e9850 2025.10.23 23:33:33.397146 [ 4712 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:33:33.443287 [ 2904 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:48262, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x00000000204bfd30 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x00000000204c0cc1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a8112cd 6. DB::ReadBuffer::next() @ 0x00000000095b468f 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000003abd729e 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:33.913682 [ 4799 ] {7fd2cc11-3b97-430d-b182-6eb2dcf617d8} executeQuery: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 64.00 GiB (attempt to allocate chunk of 68720001024 bytes), maximum: 9.31 GiB.: While executing GenerateRandom. (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48288) (comment: 01529_bad_memory_tracking.sh) (in query: SELECT i FROM generateRandom('i Array(Int8)', 1, 1, 1048577) LIMIT 65536), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000002009bbd0 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099e92 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099272 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7ca1d 7. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ff775a4 8. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x00000000083abe10 9. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:64: DB::(anonymous namespace)::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x00000000383ca9b6 10. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:0: DB::(anonymous namespace)::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x00000000383cff00 11. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:0: DB::(anonymous namespace)::GenerateSource::generate() @ 0x00000000383c77d3 12. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae71153 13. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 22. ? @ 0x00007f100c857ac3 23. ? @ 0x00007f100c8e9850 2025.10.23 23:33:33.915633 [ 4799 ] {7fd2cc11-3b97-430d-b182-6eb2dcf617d8} TCPHandler: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 64.00 GiB (attempt to allocate chunk of 68720001024 bytes), maximum: 9.31 GiB.: While executing GenerateRandom. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000002009bbd0 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099e92 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099272 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7ca1d 7. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ff775a4 8. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x00000000083abe10 9. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:64: DB::(anonymous namespace)::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x00000000383ca9b6 10. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:0: DB::(anonymous namespace)::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x00000000383cff00 11. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:0: DB::(anonymous namespace)::GenerateSource::generate() @ 0x00000000383c77d3 12. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae71153 13. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 22. ? @ 0x00007f100c857ac3 23. ? @ 0x00007f100c8e9850 2025.10.23 23:33:33.941899 [ 4713 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:33:34.136450 [ 2904 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:48298, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x00000000204bfd30 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x00000000204c0cc1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a8112cd 6. DB::ReadBuffer::next() @ 0x00000000095b468f 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000003abd729e 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:34.504037 [ 4799 ] {d19a3c5c-4e81-49f5-b987-2d4f74e75e99} executeQuery: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 64.00 GiB (attempt to allocate chunk of 68720001024 bytes), maximum: 9.31 GiB.: While executing GenerateRandom. (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48326) (comment: 01529_bad_memory_tracking.sh) (in query: SELECT i FROM generateRandom('i Array(Int8)', 1, 1, 1048577) LIMIT 65536), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000002009bbd0 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099e92 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099272 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7ca1d 7. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ff775a4 8. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x00000000083abe10 9. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:64: DB::(anonymous namespace)::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x00000000383ca9b6 10. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:0: DB::(anonymous namespace)::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x00000000383cff00 11. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:0: DB::(anonymous namespace)::GenerateSource::generate() @ 0x00000000383c77d3 12. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae71153 13. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 22. ? @ 0x00007f100c857ac3 23. ? @ 0x00007f100c8e9850 2025.10.23 23:33:34.505234 [ 4799 ] {d19a3c5c-4e81-49f5-b987-2d4f74e75e99} TCPHandler: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 64.00 GiB (attempt to allocate chunk of 68720001024 bytes), maximum: 9.31 GiB.: While executing GenerateRandom. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000002009bbd0 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099e92 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099272 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7ca1d 7. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ff775a4 8. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x00000000083abe10 9. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:64: DB::(anonymous namespace)::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x00000000383ca9b6 10. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:0: DB::(anonymous namespace)::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x00000000383cff00 11. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:0: DB::(anonymous namespace)::GenerateSource::generate() @ 0x00000000383c77d3 12. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae71153 13. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 22. ? @ 0x00007f100c857ac3 23. ? @ 0x00007f100c8e9850 2025.10.23 23:33:34.950667 [ 4713 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:48334, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x00000000204bfd30 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x00000000204c0cc1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a8112cd 6. DB::ReadBuffer::next() @ 0x00000000095b468f 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000003abd729e 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:34.994262 [ 4799 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:33:35.068591 [ 2904 ] {de1c8f38-c8c5-4dac-9243-f991767df51f} executeQuery: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 64.00 GiB (attempt to allocate chunk of 68720001024 bytes), maximum: 9.31 GiB.: While executing GenerateRandom. (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37312) (comment: 01529_bad_memory_tracking.sh) (in query: SELECT i FROM generateRandom('i Array(Int8)', 1, 1, 1048577) LIMIT 65536), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000002009bbd0 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099e92 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099272 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7ca1d 7. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ff775a4 8. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x00000000083abe10 9. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:64: DB::(anonymous namespace)::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x00000000383ca9b6 10. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:0: DB::(anonymous namespace)::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x00000000383cff00 11. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:0: DB::(anonymous namespace)::GenerateSource::generate() @ 0x00000000383c77d3 12. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae71153 13. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 22. ? @ 0x00007f100c857ac3 23. ? @ 0x00007f100c8e9850 2025.10.23 23:33:35.069537 [ 2904 ] {de1c8f38-c8c5-4dac-9243-f991767df51f} TCPHandler: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 64.00 GiB (attempt to allocate chunk of 68720001024 bytes), maximum: 9.31 GiB.: While executing GenerateRandom. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000002009bbd0 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099e92 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099272 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7ca1d 7. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ff775a4 8. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x00000000083abe10 9. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:64: DB::(anonymous namespace)::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x00000000383ca9b6 10. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:0: DB::(anonymous namespace)::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x00000000383cff00 11. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:0: DB::(anonymous namespace)::GenerateSource::generate() @ 0x00000000383c77d3 12. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae71153 13. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 22. ? @ 0x00007f100c857ac3 23. ? @ 0x00007f100c8e9850 2025.10.23 23:33:35.566486 [ 4799 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:37344, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x00000000204bfd30 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x00000000204c0cc1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a8112cd 6. DB::ReadBuffer::next() @ 0x00000000095b468f 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000003abd729e 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:35.783240 [ 2904 ] {058de20c-4e4d-465e-a321-6c2a604b6123} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37332) (comment: 01908_with_unknown_column.sql) (in query: select a from ( with a+1 as aa -- , sumIf(c, b > 0) as aaif -- , sum(if(b>0,c,0)) as aaif2 select a, sumIf(c, b > 0) as aaif3 FROM (select 1 as a, 2 as b, 3 as c) GROUP BY a ) as V;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:33:35.786432 [ 2904 ] {058de20c-4e4d-465e-a321-6c2a604b6123} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:33:36.049178 [ 4713 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:33:36.904494 [ 4636 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:37422, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x00000000204bfd30 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x00000000204c0cc1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a8112cd 6. DB::ReadBuffer::next() @ 0x00000000095b468f 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000003abd729e 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:37.166102 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:33:37.429873 [ 4672 ] {d534f07d-13ba-40a4-9415-09a2c112b497} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=734, jobs=714). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:46530) (comment: 00653_verification_monotonic_data_load.sh) (in query: SELECT count() AS `count()` FROM `test_15`.`enum_test_table` AS `__table1` WHERE toInt32(`__table1`.`val`) = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:33:37.431592 [ 4672 ] {d534f07d-13ba-40a4-9415-09a2c112b497} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=734, jobs=714). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:33:37.435280 [ 4713 ] {7a6e212b-d17d-477b-852f-2bc8b6f52cd7} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.6:9000. DB::Exception: Cannot schedule a task: fault injected (threads=734, jobs=714). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37484) (comment: 00653_verification_monotonic_data_load.sh) (in query: SELECT count() FROM enum_test_table WHERE toInt32(val) == 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002019af32 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000003a7e3e0c 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::Connection::receivePacket() @ 0x000000003a7ff61b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:340: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003a8df9b9 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:0: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000032358b71 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000323566d1 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032355a26 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000032352f12 2025.10.23 23:33:37.438337 [ 4713 ] {7a6e212b-d17d-477b-852f-2bc8b6f52cd7} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.6:9000. DB::Exception: Cannot schedule a task: fault injected (threads=734, jobs=714). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 : 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002019af32 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000003a7e3e0c 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::Connection::receivePacket() @ 0x000000003a7ff61b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:340: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003a8df9b9 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:0: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000032358b71 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000323566d1 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032355a26 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000032352f12 2025.10.23 23:33:38.252008 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:33:38.430037 [ 3895 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:37526, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x00000000204bfd30 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x00000000204c0cc1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a8112cd 6. DB::ReadBuffer::next() @ 0x00000000095b468f 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000003abd729e 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:39.329238 [ 3895 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:33:40.381982 [ 3894 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:33:40.609006 [ 4713 ] {40236cd4-e10f-46d4-bd1a-d64e171c3cad} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:37662). (NETWORK_ERROR) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37662) (comment: 00653_verification_monotonic_data_load.sh) (in query: SELECT count() FROM enum_test_table WHERE toInt8(val) == 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c6938 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000003ac044bd 6. ./contrib/llvm-project/libcxx/include/__mutex_base:253: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfbb15 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 2025.10.23 23:33:40.612530 [ 4713 ] {40236cd4-e10f-46d4-bd1a-d64e171c3cad} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:37662). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c6938 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000003ac2dd9a 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x000000003abff96a 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9aa8 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:40.612794 [ 4713 ] {40236cd4-e10f-46d4-bd1a-d64e171c3cad} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:37662). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c6938 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000003ac044bd 6. ./contrib/llvm-project/libcxx/include/__mutex_base:253: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfbb15 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 2025.10.23 23:33:40.613300 [ 4713 ] {40236cd4-e10f-46d4-bd1a-d64e171c3cad} TCPHandler: Client has gone away. 2025.10.23 23:33:41.498908 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:33:42.013049 [ 4752 ] {5d176d01-4e69-4537-a914-8db28a98b5e0} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:37796). (NETWORK_ERROR) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37796) (comment: 00653_verification_monotonic_data_load.sh) (in query: SELECT count() FROM date_test_table WHERE toInt32(val) == 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c6938 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000003ac044bd 6. ./contrib/llvm-project/libcxx/include/__mutex_base:253: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfbb15 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 2025.10.23 23:33:42.016538 [ 4752 ] {5d176d01-4e69-4537-a914-8db28a98b5e0} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:37796). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c6938 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000003ac2dd9a 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x000000003abff96a 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9aa8 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:42.016780 [ 4752 ] {5d176d01-4e69-4537-a914-8db28a98b5e0} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:37796). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c6938 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000003ac044bd 6. ./contrib/llvm-project/libcxx/include/__mutex_base:253: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfbb15 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 2025.10.23 23:33:42.017235 [ 4752 ] {5d176d01-4e69-4537-a914-8db28a98b5e0} TCPHandler: Client has gone away. 2025.10.23 23:33:42.410369 [ 4675 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:33:42.555344 [ 7760 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:33:42.571811 [ 7759 ] {0ede2cf8-a98d-4bdb-875e-3f7940314763} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=3). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37856) (comment: 03172_error_log_table_not_empty.sh) (in query: SELECT sum(value) FROM system.error_log WHERE code = 222), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202dea34 6. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039a5dbc5 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003bf2b229 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bf26bba 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003bf26345 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bf3d5b9 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2045: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf42fe0 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be48783 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003beb6da5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034cf5e6d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034cf5881 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:33:42.573367 [ 7759 ] {0ede2cf8-a98d-4bdb-875e-3f7940314763} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202dea34 6. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039a5dbc5 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003bf2b229 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bf26bba 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003bf26345 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bf3d5b9 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2045: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf42fe0 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be48783 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003beb6da5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034cf5e6d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034cf5881 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:33:42.611317 [ 4841 ] {4a1ef5d3-0517-4ea5-9158-89e719075b23} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56854) (comment: 02943_tokenbf_and_ngrambf_indexes_support_match_function.sql) (in query: DROP DATABASE IF EXISTS test_v15ryv3z ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:33:42.614039 [ 4841 ] {4a1ef5d3-0517-4ea5-9158-89e719075b23} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:42.922553 [ 7652 ] {3a8897ff-1d30-4e48-8f18-73be914c3898} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:37846). (NETWORK_ERROR) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37846) (comment: 00653_verification_monotonic_data_load.sh) (in query: SELECT count() FROM date_test_table WHERE toUInt32(val) == 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c6938 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000003ac044bd 6. ./contrib/llvm-project/libcxx/include/__mutex_base:253: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfbb15 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 2025.10.23 23:33:42.926011 [ 7652 ] {3a8897ff-1d30-4e48-8f18-73be914c3898} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:37846). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c6938 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000003ac2dd9a 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x000000003abff96a 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9aa8 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:42.926239 [ 7652 ] {3a8897ff-1d30-4e48-8f18-73be914c3898} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:37846). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c6938 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000003ac044bd 6. ./contrib/llvm-project/libcxx/include/__mutex_base:253: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfbb15 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 2025.10.23 23:33:42.926674 [ 7652 ] {3a8897ff-1d30-4e48-8f18-73be914c3898} TCPHandler: Client has gone away. 2025.10.23 23:33:43.547219 [ 7652 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:37894, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x00000000204bfd30 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x00000000204c0cc1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a8112cd 6. DB::ReadBuffer::next() @ 0x00000000095b468f 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000003abd729e 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:43.687597 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:33:44.234242 [ 2904 ] {8b504c54-4800-497e-a28c-5152915c3f5e} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=734, jobs=716). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37934) (comment: 01602_max_distributed_connections.sh) (in query: SELECT sleep(0.15) FROM remote('127.{1..10}', system.one) 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:33:44.236266 [ 2904 ] {8b504c54-4800-497e-a28c-5152915c3f5e} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=734, jobs=716). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:33:44.748215 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:33:45.104191 [ 4752 ] {eb8a83d9-8093-4d98-aa0e-c3ddb6c703ef} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37880) (comment: 02016_aggregation_spark_bar.sql) (in query: SELECT sparkbar(5,toDate('2020-01-01'),toDate('2020-01-10'))(event_date,cnt) FROM spark_bar_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:33:45.105836 [ 4752 ] {eb8a83d9-8093-4d98-aa0e-c3ddb6c703ef} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:33:45.888777 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:33:46.709439 [ 3895 ] {296e0196-3b7e-4564-b79f-d083d129a708} executeQuery: Code: 111. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(_CAST(true_Bool, 'Bool'_String) :: 1, 'error_log'_String :: 2, _CAST(111_Int16, 'Int16'_String) :: 3) -> throwIf(_CAST(true_Bool, 'Bool'_String), 'error_log'_String, _CAST(111_Int16, 'Int16'_String)) UInt8 : 4'. (CANNOT_MANIPULATE_SIGSET) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37922) (comment: 03172_error_log_table_not_empty.sh) (in query: SELECT throwIf(true, 'error_log', toInt16(111)) SETTINGS allow_custom_error_code_in_throwif=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c5725db 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d57db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffeaa 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a24ade 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b82c484 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acdc84 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae66ecb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:33:46.710681 [ 3895 ] {296e0196-3b7e-4564-b79f-d083d129a708} TCPHandler: Code: 111. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(_CAST(true_Bool, 'Bool'_String) :: 1, 'error_log'_String :: 2, _CAST(111_Int16, 'Int16'_String) :: 3) -> throwIf(_CAST(true_Bool, 'Bool'_String), 'error_log'_String, _CAST(111_Int16, 'Int16'_String)) UInt8 : 4'. (CANNOT_MANIPULATE_SIGSET), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c5725db 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d57db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffeaa 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a24ade 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b82c484 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acdc84 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae66ecb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:33:46.819638 [ 3895 ] {610bb44b-5acb-480d-998b-936f04bf0351} executeQuery: Code: 222. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(_CAST(true_Bool, 'Bool'_String) :: 1, 'error_log'_String :: 2, _CAST(222_Int16, 'Int16'_String) :: 3) -> throwIf(_CAST(true_Bool, 'Bool'_String), 'error_log'_String, _CAST(222_Int16, 'Int16'_String)) UInt8 : 4'. () (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37922) (comment: 03172_error_log_table_not_empty.sh) (in query: SELECT throwIf(true, 'error_log', toInt16(222)) SETTINGS allow_custom_error_code_in_throwif=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c5725db 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d57db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffeaa 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a24ade 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b82c484 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acdc84 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae66ecb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:33:46.820944 [ 3895 ] {610bb44b-5acb-480d-998b-936f04bf0351} TCPHandler: Code: 222. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(_CAST(true_Bool, 'Bool'_String) :: 1, 'error_log'_String :: 2, _CAST(222_Int16, 'Int16'_String) :: 3) -> throwIf(_CAST(true_Bool, 'Bool'_String), 'error_log'_String, _CAST(222_Int16, 'Int16'_String)) UInt8 : 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c5725db 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d57db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffeaa 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a24ade 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b82c484 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acdc84 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae66ecb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:33:46.887377 [ 3895 ] {0e901344-5914-4337-a1ab-bacc6315e6a0} executeQuery: Code: 333. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(_CAST(true_Bool, 'Bool'_String) :: 1, 'error_log'_String :: 2, _CAST(333_Int16, 'Int16'_String) :: 3) -> throwIf(_CAST(true_Bool, 'Bool'_String), 'error_log'_String, _CAST(333_Int16, 'Int16'_String)) UInt8 : 4'. () (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37922) (comment: 03172_error_log_table_not_empty.sh) (in query: SELECT throwIf(true, 'error_log', toInt16(333)) SETTINGS allow_custom_error_code_in_throwif=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c5725db 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d57db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffeaa 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a24ade 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b82c484 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acdc84 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae66ecb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:33:46.889071 [ 3895 ] {0e901344-5914-4337-a1ab-bacc6315e6a0} TCPHandler: Code: 333. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(_CAST(true_Bool, 'Bool'_String) :: 1, 'error_log'_String :: 2, _CAST(333_Int16, 'Int16'_String) :: 3) -> throwIf(_CAST(true_Bool, 'Bool'_String), 'error_log'_String, _CAST(333_Int16, 'Int16'_String)) UInt8 : 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c5725db 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d57db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffeaa 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a24ade 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b82c484 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acdc84 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae66ecb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:33:46.963593 [ 4713 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:33:47.040135 [ 7652 ] {2b558c8e-10a3-42a0-ac88-b93089be13a0} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:37998, local: [::1]:9000). (NETWORK_ERROR) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37998) (comment: 01602_max_distributed_connections.sh) (in query: SELECT sleep(0.15) FROM remote('127.{1..10}', system.one) 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x00000000204bfd30 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x00000000204c0cc1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a8112cd 6. DB::ReadBuffer::next() @ 0x00000000095b468f 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::getQueryCancellationStatus() @ 0x000000003ac0b9f9 8. ./build_docker/./src/Server/TCPHandler.cpp:1113: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb7e4 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:33:47.042826 [ 4745 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:54832, local: [::ffff:127.0.0.6]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x00000000204bfd30 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x00000000204c0cc1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a8112cd 6. DB::ReadBuffer::next() @ 0x00000000095b468f 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000003abd729e 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:47.044900 [ 4712 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:54168, 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x00000000204bfd30 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x00000000204c0cc1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a8112cd 6. DB::ReadBuffer::next() @ 0x00000000095b468f 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000003abd729e 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:47.047285 [ 4675 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:57764, 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x00000000204bfd30 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x00000000204c0cc1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a8112cd 6. DB::ReadBuffer::next() @ 0x00000000095b468f 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000003abd729e 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:47.049067 [ 4752 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:32906, 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x00000000204bfd30 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x00000000204c0cc1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a8112cd 6. DB::ReadBuffer::next() @ 0x00000000095b468f 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000003abd729e 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:47.050264 [ 3894 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:42942, 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x00000000204bfd30 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x00000000204c0cc1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a8112cd 6. DB::ReadBuffer::next() @ 0x00000000095b468f 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000003abd729e 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:47.052393 [ 7652 ] {2b558c8e-10a3-42a0-ac88-b93089be13a0} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:37998). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c6938 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000003ac2dd9a 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x000000003abff96a 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9aa8 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:47.052648 [ 7652 ] {2b558c8e-10a3-42a0-ac88-b93089be13a0} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:37998, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x00000000204bfd30 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x00000000204c0cc1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a8112cd 6. DB::ReadBuffer::next() @ 0x00000000095b468f 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::getQueryCancellationStatus() @ 0x000000003ac0b9f9 8. ./build_docker/./src/Server/TCPHandler.cpp:1113: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb7e4 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:33:47.053102 [ 7652 ] {2b558c8e-10a3-42a0-ac88-b93089be13a0} TCPHandler: Client has gone away. 2025.10.23 23:33:47.118680 [ 4841 ] {b6f8b8b3-6033-4364-bd20-8a8c00eb2e9d} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:58944) (comment: 01232_untuple.sql) (in query: DROP DATABASE IF EXISTS test_k4b6x65q ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:33:47.121072 [ 4841 ] {b6f8b8b3-6033-4364-bd20-8a8c00eb2e9d} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:48.064246 [ 4713 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:33:48.141710 [ 3655 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {8c494fec-2d59-4135-a0d6-29ba8d5d4dac::202510_1_11_2}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 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) @ 0x0000000039c89948 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000003999bfb7 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 @ 0x00000000399942f0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000039d15c04 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&) @ 0x0000000039d20399 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) @ 0x0000000039d1c606 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000396308a4 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x00000000396235dd 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000003963b3e0 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x00000000396504a0 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3c455d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:49.156600 [ 4672 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:33:50.216085 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:33:50.809057 [ 7565 ] {5d86aadb-269f-4790-b829-fe2c5fff3583} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38002) (comment: 02099_tsv_raw_format_1.sh) (in query: SELECT * FROM test_nullable_02099), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:33:50.810618 [ 7565 ] {5d86aadb-269f-4790-b829-fe2c5fff3583} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:33:51.264188 [ 7760 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:33:51.981702 [ 3657 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {959c1387-6a29-41af-9a70-593d11e44aac::202510_1_26_5}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 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) @ 0x0000000039c89948 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000003999bfb7 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 @ 0x00000000399942f0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000039d15c04 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&) @ 0x0000000039d20399 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) @ 0x0000000039d1c606 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000396308a4 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x00000000396235dd 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000003963b3e0 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x00000000396504a0 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3c455d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:52.319681 [ 7760 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:33:53.377355 [ 6961 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:33:53.926901 [ 7652 ] {7ed6e6a8-6eb7-4bf6-b491-3f21ecd4f059} executeQuery: Code: 111. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(_CAST(true_Bool, 'Bool'_String) :: 1, 'error_log'_String :: 2, _CAST(111_Int16, 'Int16'_String) :: 3) -> throwIf(_CAST(true_Bool, 'Bool'_String), 'error_log'_String, _CAST(111_Int16, 'Int16'_String)) UInt8 : 4'. (CANNOT_MANIPULATE_SIGSET) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38178) (comment: 03172_error_log_table_not_empty.sh) (in query: SELECT throwIf(true, 'error_log', toInt16(111)) SETTINGS allow_custom_error_code_in_throwif=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c5725db 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d57db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffeaa 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a24ade 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b82c484 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acdc84 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae66ecb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:33:53.928121 [ 7652 ] {7ed6e6a8-6eb7-4bf6-b491-3f21ecd4f059} TCPHandler: Code: 111. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(_CAST(true_Bool, 'Bool'_String) :: 1, 'error_log'_String :: 2, _CAST(111_Int16, 'Int16'_String) :: 3) -> throwIf(_CAST(true_Bool, 'Bool'_String), 'error_log'_String, _CAST(111_Int16, 'Int16'_String)) UInt8 : 4'. (CANNOT_MANIPULATE_SIGSET), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c5725db 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d57db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffeaa 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a24ade 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b82c484 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acdc84 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae66ecb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:33:53.957260 [ 7652 ] {2ea2a4a9-8af1-4278-8155-988fef29f894} executeQuery: Code: 222. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(_CAST(true_Bool, 'Bool'_String) :: 1, 'error_log'_String :: 2, _CAST(222_Int16, 'Int16'_String) :: 3) -> throwIf(_CAST(true_Bool, 'Bool'_String), 'error_log'_String, _CAST(222_Int16, 'Int16'_String)) UInt8 : 4'. () (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38178) (comment: 03172_error_log_table_not_empty.sh) (in query: SELECT throwIf(true, 'error_log', toInt16(222)) SETTINGS allow_custom_error_code_in_throwif=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c5725db 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d57db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffeaa 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a24ade 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b82c484 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acdc84 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae66ecb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:33:53.958336 [ 7652 ] {2ea2a4a9-8af1-4278-8155-988fef29f894} TCPHandler: Code: 222. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(_CAST(true_Bool, 'Bool'_String) :: 1, 'error_log'_String :: 2, _CAST(222_Int16, 'Int16'_String) :: 3) -> throwIf(_CAST(true_Bool, 'Bool'_String), 'error_log'_String, _CAST(222_Int16, 'Int16'_String)) UInt8 : 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c5725db 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d57db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffeaa 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a24ade 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b82c484 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acdc84 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae66ecb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:33:53.983614 [ 7652 ] {daefe1e5-499a-49e4-8795-a5464f73b70f} executeQuery: Code: 333. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(_CAST(true_Bool, 'Bool'_String) :: 1, 'error_log'_String :: 2, _CAST(333_Int16, 'Int16'_String) :: 3) -> throwIf(_CAST(true_Bool, 'Bool'_String), 'error_log'_String, _CAST(333_Int16, 'Int16'_String)) UInt8 : 4'. () (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38178) (comment: 03172_error_log_table_not_empty.sh) (in query: SELECT throwIf(true, 'error_log', toInt16(333)) SETTINGS allow_custom_error_code_in_throwif=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c5725db 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d57db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffeaa 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a24ade 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b82c484 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acdc84 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae66ecb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:33:53.984695 [ 7652 ] {daefe1e5-499a-49e4-8795-a5464f73b70f} TCPHandler: Code: 333. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(_CAST(true_Bool, 'Bool'_String) :: 1, 'error_log'_String :: 2, _CAST(333_Int16, 'Int16'_String) :: 3) -> throwIf(_CAST(true_Bool, 'Bool'_String), 'error_log'_String, _CAST(333_Int16, 'Int16'_String)) UInt8 : 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c5725db 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d57db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffeaa 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a24ade 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b82c484 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acdc84 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae66ecb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:33:54.241829 [ 7759 ] {} ServerErrorHandler: Code: 516. DB::Exception: non_exist_user: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./src/Access/Credentials.h:54: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000035095429 6. ./contrib/llvm-project/libcxx/include/vector:438: DB::TCPHandler::receiveHello() @ 0x000000003abee89f 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd5a84 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:54.465202 [ 6969 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:33:54.909358 [ 3656 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b525ce1d-7280-45ee-88a5-bc3438c6d2d5::202510_1_20_4}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 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) @ 0x0000000039c89948 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000003999bfb7 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 @ 0x00000000399942f0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000039d15c04 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&) @ 0x0000000039d20399 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) @ 0x0000000039d1c606 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000396308a4 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x00000000396235dd 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000003963b3e0 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x00000000396504a0 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3c455d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:55.544084 [ 4675 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:33:55.745518 [ 7760 ] {} ServerErrorHandler: 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./src/Access/Credentials.h:54: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000035095429 6. ./contrib/llvm-project/libcxx/include/vector:438: DB::TCPHandler::receiveHello() @ 0x000000003abee89f 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd5a84 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:56.573853 [ 4675 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:33:57.650947 [ 4752 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:33:58.708657 [ 7760 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:33:59.768806 [ 3894 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:34:00.842220 [ 3894 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:34:01.929337 [ 4712 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:34:03.046229 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:34:03.987561 [ 4713 ] {67fcf8b2-393f-421c-85f0-ad36b2d0c141} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:55902) (comment: 02047_log_family_data_file_sizes.sh) (in query: SELECT * FROM tbl 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:34:03.990027 [ 4713 ] {67fcf8b2-393f-421c-85f0-ad36b2d0c141} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:34:04.195410 [ 4712 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:34:05.238189 [ 2904 ] {b1878712-3d15-4f7e-97b7-c7ed71319e5d} executeQuery: Code: 57. DB::Exception: Table test_3.tbl already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37620) (comment: 02047_log_family_data_file_sizes.sh) (in query: CREATE TABLE tbl(x UInt32, y String) 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:34:05.251908 [ 2904 ] {b1878712-3d15-4f7e-97b7-c7ed71319e5d} TCPHandler: Code: 57. DB::Exception: Table test_3.tbl already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:34:05.278433 [ 7760 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:34:06.327907 [ 7760 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:34:06.947409 [ 3656 ] {504e6da2-525b-4fa9-81f7-f6dc1f9f2a1a::20010101_2_2_0_3} MutatePlainMergeTreeTask: Code: 6. DB::Exception: Cannot parse string 'b' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT) (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:06.959958 [ 3650 ] {504e6da2-525b-4fa9-81f7-f6dc1f9f2a1a::20000101_1_1_0_3} MutatePlainMergeTreeTask: Code: 6. DB::Exception: Cannot parse string 'a' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT) (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:07.374838 [ 4672 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:34:08.145814 [ 4675 ] {e5c4d97c-b108-4e30-9ff9-9d254302b90c} executeQuery: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_3.txt' with part '20010101_2_2_0' reason: 'Code: 6. DB::Exception: Cannot parse string 'b' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT) (version 24.8.14.10542.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.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 00834_kill_mutation.sh) (in query: /* ddl_entry=query-0000000014 */ ALTER TABLE test_11.kill_mutation DELETE WHERE toUInt32(s) = 1 SETTINGS mutations_sync = 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&) @ 0x0000000039c1c97f 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000039c1c6e5 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003a2fe259 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003a3016f5 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034866f33 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003485e550 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003395fc9e 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000033958fac 13. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ad726d 14. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a52a3c 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034861fe8 16. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003485e550 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 26. ? @ 0x00007f100c857ac3 27. ? @ 0x00007f100c8e9850 2025.10.23 23:34:08.152306 [ 4675 ] {e5c4d97c-b108-4e30-9ff9-9d254302b90c} executeQuery: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_3.txt' with part '20010101_2_2_0' reason: 'Code: 6. DB::Exception: Cannot parse string 'b' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT) (version 24.8.14.10542.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.10542.altinitytest (altinity build)) (from [::1]:37884) (comment: 00834_kill_mutation.sh) (in query: ALTER TABLE kill_mutation DELETE WHERE toUInt32(s) = 1 SETTINGS mutations_sync = 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&) @ 0x0000000039c1c97f 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000039c1c6e5 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003a2fe259 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003a3016f5 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034866f33 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003485e550 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003395fc9e 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000033958fac 13. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ad726d 14. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a52a3c 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034861fe8 16. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003485e550 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 26. ? @ 0x00007f100c857ac3 27. ? @ 0x00007f100c8e9850 2025.10.23 23:34:08.154021 [ 4675 ] {e5c4d97c-b108-4e30-9ff9-9d254302b90c} TCPHandler: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_3.txt' with part '20010101_2_2_0' reason: 'Code: 6. DB::Exception: Cannot parse string 'b' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT) (version 24.8.14.10542.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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&) @ 0x0000000039c1c97f 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000039c1c6e5 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003a2fe259 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003a3016f5 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034866f33 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003485e550 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003395fc9e 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000033958fac 13. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ad726d 14. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a52a3c 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034861fe8 16. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003485e550 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 26. ? @ 0x00007f100c857ac3 27. ? @ 0x00007f100c8e9850 2025.10.23 23:34:08.198737 [ 3656 ] {504e6da2-525b-4fa9-81f7-f6dc1f9f2a1a::20010101_2_2_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 6. DB::Exception: Cannot parse string 'b' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086ed802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000885710a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008832c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d57db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffeaa 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a24ade 11. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000003b839ca1 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000003b839784 13. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acdc84 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae66ecb 15. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 21. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:08.198743 [ 3650 ] {504e6da2-525b-4fa9-81f7-f6dc1f9f2a1a::20000101_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 6. DB::Exception: Cannot parse string 'a' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086ed802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000885710a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008832c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d57db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffeaa 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a24ade 11. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000003b839ca1 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000003b839784 13. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acdc84 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae66ecb 15. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 21. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:08.235811 [ 3657 ] {504e6da2-525b-4fa9-81f7-f6dc1f9f2a1a::20000101_1_1_0_3} MutatePlainMergeTreeTask: Code: 6. DB::Exception: Cannot parse string 'a' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT) (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:08.236410 [ 3657 ] {504e6da2-525b-4fa9-81f7-f6dc1f9f2a1a::20000101_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 6. DB::Exception: Cannot parse string 'a' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086ed802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000885710a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008832c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d57db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffeaa 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a24ade 11. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000003b839ca1 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000003b839784 13. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acdc84 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae66ecb 15. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 21. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:08.238417 [ 3655 ] {504e6da2-525b-4fa9-81f7-f6dc1f9f2a1a::20010101_2_2_0_3} MutatePlainMergeTreeTask: Code: 6. DB::Exception: Cannot parse string 'b' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT) (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:08.238950 [ 3655 ] {504e6da2-525b-4fa9-81f7-f6dc1f9f2a1a::20010101_2_2_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 6. DB::Exception: Cannot parse string 'b' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086ed802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000885710a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008832c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d57db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffeaa 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a24ade 11. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000003b839ca1 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000003b839784 13. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acdc84 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae66ecb 15. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 21. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:08.406634 [ 4672 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:34:09.285734 [ 3658 ] {504e6da2-525b-4fa9-81f7-f6dc1f9f2a1a::20000101_1_1_0_3} MutatePlainMergeTreeTask: Code: 6. DB::Exception: Cannot parse string 'a' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT) (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:09.286572 [ 3658 ] {504e6da2-525b-4fa9-81f7-f6dc1f9f2a1a::20000101_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 6. DB::Exception: Cannot parse string 'a' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086ed802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000885710a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008832c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d57db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffeaa 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a24ade 11. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000003b839ca1 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000003b839784 13. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acdc84 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae66ecb 15. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 21. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:09.388751 [ 3646 ] {504e6da2-525b-4fa9-81f7-f6dc1f9f2a1a::20010101_2_2_0_3} MutatePlainMergeTreeTask: Code: 6. DB::Exception: Cannot parse string 'b' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT) (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:09.389190 [ 3646 ] {504e6da2-525b-4fa9-81f7-f6dc1f9f2a1a::20010101_2_2_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 6. DB::Exception: Cannot parse string 'b' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086ed802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000885710a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008832c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d57db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffeaa 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a24ade 11. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000003b839ca1 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000003b839784 13. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acdc84 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae66ecb 15. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 21. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:09.449899 [ 4745 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:34:09.513205 [ 3656 ] {504e6da2-525b-4fa9-81f7-f6dc1f9f2a1a::20000101_1_1_0_3} MutatePlainMergeTreeTask: Code: 6. DB::Exception: Cannot parse string 'a' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT) (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:09.513594 [ 3656 ] {504e6da2-525b-4fa9-81f7-f6dc1f9f2a1a::20000101_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 6. DB::Exception: Cannot parse string 'a' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086ed802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000885710a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008832c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d57db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffeaa 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a24ade 11. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000003b839ca1 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000003b839784 13. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acdc84 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae66ecb 15. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 21. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:09.641920 [ 3643 ] {504e6da2-525b-4fa9-81f7-f6dc1f9f2a1a::20010101_2_2_0_3} MutatePlainMergeTreeTask: Code: 6. DB::Exception: Cannot parse string 'b' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT) (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:09.642363 [ 3643 ] {504e6da2-525b-4fa9-81f7-f6dc1f9f2a1a::20010101_2_2_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 6. DB::Exception: Cannot parse string 'b' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086ed802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000885710a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008832c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d57db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffeaa 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a24ade 11. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000003b839ca1 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000003b839784 13. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acdc84 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae66ecb 15. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 21. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:09.976334 [ 3674 ] {} test_15.r4 (b8428b65-4036-49d1-a93a-c7c1bd72c4c3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_2_2_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:09.976366 [ 3673 ] {} test_15.r5 (1b626045-cf30-44b2-91f1-3165d43b86e1): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_2_2_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:09.976409 [ 3672 ] {} test_15.r1 (a9e12f64-7d79-4642-a352-4087db67ff97): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr5&part=all_0_0_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:09.976429 [ 3678 ] {} test_15.r4 (b8428b65-4036-49d1-a93a-c7c1bd72c4c3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_1_1_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:09.976804 [ 3675 ] {} test_15.r1 (a9e12f64-7d79-4642-a352-4087db67ff97): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr5&part=all_4_4_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:09.976409 [ 3670 ] {} test_15.r5 (1b626045-cf30-44b2-91f1-3165d43b86e1): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_1_1_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:09.976916 [ 3682 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr5&part=all_5_5_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:09.977382 [ 3681 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr5&part=all_3_3_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:09.977433 [ 3668 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr5&part=all_4_4_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:09.977510 [ 3667 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_2_2_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:09.977594 [ 3679 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_1_1_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:09.977618 [ 3669 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr5&part=all_0_0_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:09.978198 [ 3671 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_2_2_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:09.978257 [ 3680 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr5&part=all_0_0_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:09.978350 [ 3677 ] {} test_15.r4 (b8428b65-4036-49d1-a93a-c7c1bd72c4c3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr5&part=all_4_4_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:09.997263 [ 3676 ] {} test_15.r4 (b8428b65-4036-49d1-a93a-c7c1bd72c4c3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr5&part=all_0_0_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:10.033979 [ 6969 ] {3937ab24-6720-45ff-ba51-19b9925f4fd1} executeQuery: Code: 57. DB::Exception: Table test_3.tbl already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38378) (comment: 02047_log_family_data_file_sizes.sh) (in query: CREATE TABLE tbl(x UInt32, y String) ENGINE=StripeLog), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:34:10.035951 [ 6969 ] {3937ab24-6720-45ff-ba51-19b9925f4fd1} TCPHandler: Code: 57. DB::Exception: Table test_3.tbl already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:34:10.106457 [ 3682 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr2&part=all_9_9_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:10.107194 [ 3672 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_2_2_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:10.217874 [ 3675 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_1_1_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:10.360168 [ 3680 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr2&part=all_10_10_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:10.363808 [ 3676 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_14_14_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:10.364507 [ 3671 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr2&part=all_7_7_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:10.376124 [ 3675 ] {} test_15.r5 (1b626045-cf30-44b2-91f1-3165d43b86e1): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_2_2_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:10.429114 [ 3682 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr2&part=all_9_9_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:10.435891 [ 3679 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_2_2_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:10.456737 [ 3678 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr2&part=all_18_18_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:10.515634 [ 3895 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:34:10.520486 [ 3681 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr2&part=all_9_9_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:10.543138 [ 3680 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr2&part=all_10_10_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:10.555166 [ 3678 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_2_2_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:10.555480 [ 3677 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_14_14_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:10.568141 [ 3675 ] {} test_15.r5 (1b626045-cf30-44b2-91f1-3165d43b86e1): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_1_1_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:10.597126 [ 3679 ] {} test_15.r4 (b8428b65-4036-49d1-a93a-c7c1bd72c4c3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_2_2_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:10.605343 [ 3671 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_1_1_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:10.615532 [ 3672 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_1_1_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:11.331075 [ 3675 ] {} test_15.r1 (a9e12f64-7d79-4642-a352-4087db67ff97): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr5&part=all_26_26_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:11.344890 [ 3674 ] {} test_15.r4 (b8428b65-4036-49d1-a93a-c7c1bd72c4c3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_15_15_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:11.353183 [ 3671 ] {} test_15.r4 (b8428b65-4036-49d1-a93a-c7c1bd72c4c3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_16_16_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:11.363492 [ 3682 ] {} test_15.r4 (b8428b65-4036-49d1-a93a-c7c1bd72c4c3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_17_17_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:11.386542 [ 3677 ] {} test_15.r1 (a9e12f64-7d79-4642-a352-4087db67ff97): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr5&part=all_26_26_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:11.451579 [ 3680 ] {} test_15.r1 (a9e12f64-7d79-4642-a352-4087db67ff97): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr5&part=all_26_26_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:11.528944 [ 3671 ] {} test_15.r4 (b8428b65-4036-49d1-a93a-c7c1bd72c4c3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr5&part=all_26_26_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:11.528974 [ 3682 ] {} test_15.r4 (b8428b65-4036-49d1-a93a-c7c1bd72c4c3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_16_16_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:11.529036 [ 3669 ] {} test_15.r4 (b8428b65-4036-49d1-a93a-c7c1bd72c4c3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_9_9_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:11.541285 [ 3680 ] {} test_15.r4 (b8428b65-4036-49d1-a93a-c7c1bd72c4c3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr5&part=all_26_26_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:11.581531 [ 3676 ] {} test_15.r4 (b8428b65-4036-49d1-a93a-c7c1bd72c4c3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr5&part=all_26_26_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:11.592272 [ 3669 ] {} test_15.r1 (a9e12f64-7d79-4642-a352-4087db67ff97): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr5&part=all_26_26_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:11.595925 [ 3675 ] {} test_15.r4 (b8428b65-4036-49d1-a93a-c7c1bd72c4c3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr5&part=all_26_26_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:11.609750 [ 4675 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:34:11.788705 [ 3680 ] {} test_15.r1 (a9e12f64-7d79-4642-a352-4087db67ff97): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr5&part=all_26_26_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:11.797705 [ 3679 ] {} test_15.r4 (b8428b65-4036-49d1-a93a-c7c1bd72c4c3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr5&part=all_26_26_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:11.951947 [ 3682 ] {} test_15.r4 (b8428b65-4036-49d1-a93a-c7c1bd72c4c3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr5&part=all_26_26_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:11.952949 [ 3673 ] {} test_15.r1 (a9e12f64-7d79-4642-a352-4087db67ff97): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr5&part=all_26_26_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:12.016145 [ 3653 ] {504e6da2-525b-4fa9-81f7-f6dc1f9f2a1a::20010101_2_2_0_4} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=4). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:12.016519 [ 3653 ] {504e6da2-525b-4fa9-81f7-f6dc1f9f2a1a::20010101_2_2_0_4} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=4). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:12.045409 [ 3649 ] {504e6da2-525b-4fa9-81f7-f6dc1f9f2a1a::20000101_1_1_0_4} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:12.045837 [ 3649 ] {504e6da2-525b-4fa9-81f7-f6dc1f9f2a1a::20000101_1_1_0_4} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:12.053362 [ 3672 ] {} test_15.r4 (b8428b65-4036-49d1-a93a-c7c1bd72c4c3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr5&part=all_26_26_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:12.071355 [ 3657 ] {504e6da2-525b-4fa9-81f7-f6dc1f9f2a1a::20010101_2_2_0_4} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:12.071821 [ 3657 ] {504e6da2-525b-4fa9-81f7-f6dc1f9f2a1a::20010101_2_2_0_4} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:12.085498 [ 3655 ] {504e6da2-525b-4fa9-81f7-f6dc1f9f2a1a::20000101_1_1_0_4} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, jobs=14). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:12.085906 [ 3655 ] {504e6da2-525b-4fa9-81f7-f6dc1f9f2a1a::20000101_1_1_0_4} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, jobs=14). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:12.105261 [ 3670 ] {} test_15.r1 (a9e12f64-7d79-4642-a352-4087db67ff97): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr5&part=all_26_26_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:12.114294 [ 3667 ] {} test_15.r4 (b8428b65-4036-49d1-a93a-c7c1bd72c4c3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr5&part=all_26_26_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:12.119026 [ 3644 ] {504e6da2-525b-4fa9-81f7-f6dc1f9f2a1a::20000101_1_1_0_4} MutatePlainMergeTreeTask: Code: 6. DB::Exception: Cannot parse string 'a' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT) (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:12.119400 [ 3644 ] {504e6da2-525b-4fa9-81f7-f6dc1f9f2a1a::20000101_1_1_0_4} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 6. DB::Exception: Cannot parse string 'a' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086ed802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000885710a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008832c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d57db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffeaa 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a24ade 11. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000003b839ca1 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000003b839784 13. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acdc84 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae66ecb 15. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 21. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:12.151164 [ 3669 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr5&part=all_26_26_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:12.161658 [ 3651 ] {504e6da2-525b-4fa9-81f7-f6dc1f9f2a1a::20010101_2_2_0_4} 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.10542.altinitytest (altinity build)) 2025.10.23 23:34:12.162029 [ 3651 ] {504e6da2-525b-4fa9-81f7-f6dc1f9f2a1a::20010101_2_2_0_4} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:12.169195 [ 3672 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr5&part=all_26_26_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:12.181501 [ 3671 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr5&part=all_26_26_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:12.190006 [ 3667 ] {} test_15.r5 (1b626045-cf30-44b2-91f1-3165d43b86e1): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_1_1_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:12.200092 [ 3657 ] {504e6da2-525b-4fa9-81f7-f6dc1f9f2a1a::20000101_1_1_0_4} MutatePlainMergeTreeTask: Code: 6. DB::Exception: Cannot parse string 'a' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT) (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:12.200456 [ 3657 ] {504e6da2-525b-4fa9-81f7-f6dc1f9f2a1a::20000101_1_1_0_4} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 6. DB::Exception: Cannot parse string 'a' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086ed802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000885710a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008832c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d57db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffeaa 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a24ade 11. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000003b839ca1 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000003b839784 13. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acdc84 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae66ecb 15. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 21. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:12.233319 [ 3649 ] {504e6da2-525b-4fa9-81f7-f6dc1f9f2a1a::20010101_2_2_0_4} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=11, jobs=11). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:12.250848 [ 3654 ] {} 37341e51-1a17-4c44-9987-141583b579a2::all_3_13_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 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) @ 0x0000000039c89948 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000003999bfb7 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 @ 0x00000000399942f0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000039d15c04 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&) @ 0x0000000039d20399 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) @ 0x0000000039d1c606 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000396308a4 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x00000000396235dd 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000003963b3e0 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x00000000396504a0 19. ./src/Storages/MergeTree/MergeFromLogEntryTask.h:36: DB::MergeFromLogEntryTask::executeInnerTask() @ 0x0000000039605f46 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a02473e 21. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 26. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 28. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 30. ? @ 0x00007f100c857ac3 31. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:12.356860 [ 3649 ] {504e6da2-525b-4fa9-81f7-f6dc1f9f2a1a::20010101_2_2_0_4} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=11, jobs=11). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:12.357195 [ 3654 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {37341e51-1a17-4c44-9987-141583b579a2::all_3_13_1}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 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) @ 0x0000000039c89948 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000003999bfb7 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 @ 0x00000000399942f0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000039d15c04 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&) @ 0x0000000039d20399 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) @ 0x0000000039d1c606 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000396308a4 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x00000000396235dd 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000003963b3e0 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x00000000396504a0 19. ./src/Storages/MergeTree/MergeFromLogEntryTask.h:36: DB::MergeFromLogEntryTask::executeInnerTask() @ 0x0000000039605f46 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a02473e 21. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 26. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 28. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 30. ? @ 0x00007f100c857ac3 31. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:12.369089 [ 3672 ] {} test_15.r1 (a9e12f64-7d79-4642-a352-4087db67ff97): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr5&part=all_26_26_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:12.420135 [ 3673 ] {} test_15.r1 (a9e12f64-7d79-4642-a352-4087db67ff97): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr5&part=all_26_26_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:12.423473 [ 3681 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr5&part=all_26_26_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:12.489125 [ 3658 ] {504e6da2-525b-4fa9-81f7-f6dc1f9f2a1a::20010101_2_2_0_4} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=8, jobs=8). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:12.489501 [ 3658 ] {504e6da2-525b-4fa9-81f7-f6dc1f9f2a1a::20010101_2_2_0_4} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:12.644468 [ 3643 ] {504e6da2-525b-4fa9-81f7-f6dc1f9f2a1a::20000101_1_1_0_4} MutatePlainMergeTreeTask: Code: 6. DB::Exception: Cannot parse string 'a' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT) (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:12.644878 [ 3643 ] {504e6da2-525b-4fa9-81f7-f6dc1f9f2a1a::20000101_1_1_0_4} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 6. DB::Exception: Cannot parse string 'a' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086ed802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000885710a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008832c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d57db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffeaa 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a24ade 11. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000003b839ca1 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000003b839784 13. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acdc84 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae66ecb 15. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 21. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:12.677849 [ 3175 ] {} test_15.r5 (ReplicatedMergeTreePartCheckThread): We have part all_14_20_1 covering part all_18_18_0, will not check 2025.10.23 23:34:12.684574 [ 3175 ] {} test_15.r5 (ReplicatedMergeTreePartCheckThread): We have part all_14_20_1 covering part all_16_16_0, will not check 2025.10.23 23:34:12.686206 [ 3175 ] {} test_15.r5 (ReplicatedMergeTreePartCheckThread): We have part all_14_20_1 covering part all_17_17_0, will not check 2025.10.23 23:34:12.691816 [ 3175 ] {} test_15.r5 (ReplicatedMergeTreePartCheckThread): We have part all_14_20_1 covering part all_15_15_0, will not check 2025.10.23 23:34:12.700987 [ 3652 ] {504e6da2-525b-4fa9-81f7-f6dc1f9f2a1a::20010101_2_2_0_4} 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.10542.altinitytest (altinity build)) 2025.10.23 23:34:12.701336 [ 3652 ] {504e6da2-525b-4fa9-81f7-f6dc1f9f2a1a::20010101_2_2_0_4} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:12.748356 [ 3654 ] {504e6da2-525b-4fa9-81f7-f6dc1f9f2a1a::20000101_1_1_0_4} MutatePlainMergeTreeTask: Code: 6. DB::Exception: Cannot parse string 'a' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT) (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:12.748745 [ 3654 ] {504e6da2-525b-4fa9-81f7-f6dc1f9f2a1a::20000101_1_1_0_4} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 6. DB::Exception: Cannot parse string 'a' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086ed802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000885710a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008832c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d57db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffeaa 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a24ade 11. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000003b839ca1 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000003b839784 13. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acdc84 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae66ecb 15. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 21. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:12.750851 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:34:12.871635 [ 3650 ] {504e6da2-525b-4fa9-81f7-f6dc1f9f2a1a::20010101_2_2_0_5} MutatePlainMergeTreeTask: Code: 6. DB::Exception: Cannot parse string 'b' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 3'. (CANNOT_PARSE_TEXT) (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:12.872201 [ 3650 ] {504e6da2-525b-4fa9-81f7-f6dc1f9f2a1a::20010101_2_2_0_5} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 6. DB::Exception: Cannot parse string 'b' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 3'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086ed802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000885710a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008832c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d57db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffeaa 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a24ade 11. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000003b839ca1 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000003b839784 13. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acdc84 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae66ecb 15. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 21. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:12.872757 [ 4672 ] {9accc7f7-f6c1-4a4e-b37c-36b25e843836} executeQuery: Code: 341. DB::Exception: Exception happened during execution of mutations 'mutation_4.txt, mutation_5.txt' with part '20010101_2_2_0' reason: 'Code: 6. DB::Exception: Cannot parse string 'b' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 3'. (CANNOT_PARSE_TEXT) (version 24.8.14.10542.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.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 00834_kill_mutation.sh) (in query: /* ddl_entry=query-0000000016 */ ALTER TABLE test_11.kill_mutation DELETE WHERE x = 1 SETTINGS mutations_sync = 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&) @ 0x0000000039c1c97f 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000039c1c6e5 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003a2fe259 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003a3016f5 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034866f33 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003485e550 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003395fc9e 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000033958fac 13. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ad726d 14. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a52a3c 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034861fe8 16. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003485e550 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 26. ? @ 0x00007f100c857ac3 27. ? @ 0x00007f100c8e9850 2025.10.23 23:34:12.892102 [ 3658 ] {504e6da2-525b-4fa9-81f7-f6dc1f9f2a1a::20000101_1_1_0_5} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:12.892449 [ 3658 ] {504e6da2-525b-4fa9-81f7-f6dc1f9f2a1a::20000101_1_1_0_5} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:12.958879 [ 4672 ] {9accc7f7-f6c1-4a4e-b37c-36b25e843836} executeQuery: Code: 341. DB::Exception: Exception happened during execution of mutations 'mutation_4.txt, mutation_5.txt' with part '20010101_2_2_0' reason: 'Code: 6. DB::Exception: Cannot parse string 'b' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 3'. (CANNOT_PARSE_TEXT) (version 24.8.14.10542.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.10542.altinitytest (altinity build)) (from [::1]:38802) (comment: 00834_kill_mutation.sh) (in query: ALTER TABLE kill_mutation DELETE WHERE x = 1 SETTINGS mutations_sync = 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&) @ 0x0000000039c1c97f 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000039c1c6e5 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003a2fe259 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003a3016f5 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034866f33 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003485e550 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003395fc9e 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000033958fac 13. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ad726d 14. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a52a3c 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034861fe8 16. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003485e550 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 26. ? @ 0x00007f100c857ac3 27. ? @ 0x00007f100c8e9850 2025.10.23 23:34:12.961277 [ 4672 ] {9accc7f7-f6c1-4a4e-b37c-36b25e843836} TCPHandler: Code: 341. DB::Exception: Exception happened during execution of mutations 'mutation_4.txt, mutation_5.txt' with part '20010101_2_2_0' reason: 'Code: 6. DB::Exception: Cannot parse string 'b' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 3'. (CANNOT_PARSE_TEXT) (version 24.8.14.10542.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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&) @ 0x0000000039c1c97f 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000039c1c6e5 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003a2fe259 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003a3016f5 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034866f33 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003485e550 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003395fc9e 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000033958fac 13. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ad726d 14. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a52a3c 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034861fe8 16. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003485e550 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 26. ? @ 0x00007f100c857ac3 27. ? @ 0x00007f100c8e9850 2025.10.23 23:34:13.009608 [ 6969 ] {990e75cc-6510-4aa3-90e3-fc658deb8e74} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38420) (comment: 01440_to_date_monotonicity.sql) (in query: CREATE TABLE tdm2 (`timestamp` UInt32) ENGINE = MergeTree ORDER BY timestamp SETTINGS index_granularity = 1, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 56501578, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 17300842, merge_max_block_size = 21128, old_parts_lifetime = 306., 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 = 10737418240, index_granularity_bytes = 782346, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 19513, primary_key_compress_block_size = 54957), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x0000000039709f85 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>) @ 0x000000003a2e5f4a 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a2e404f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2d3063 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7b27a 12. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x0000000038308626 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348e414c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:34:13.014120 [ 6969 ] {990e75cc-6510-4aa3-90e3-fc658deb8e74} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x0000000039709f85 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>) @ 0x000000003a2e5f4a 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a2e404f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2d3063 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7b27a 12. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x0000000038308626 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348e414c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:34:13.824178 [ 3651 ] {504e6da2-525b-4fa9-81f7-f6dc1f9f2a1a::20010101_2_2_0_5} MutatePlainMergeTreeTask: Code: 6. DB::Exception: Cannot parse string 'b' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 3'. (CANNOT_PARSE_TEXT) (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:13.824755 [ 3651 ] {504e6da2-525b-4fa9-81f7-f6dc1f9f2a1a::20010101_2_2_0_5} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 6. DB::Exception: Cannot parse string 'b' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 3'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086ed802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000885710a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008832c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d57db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffeaa 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a24ade 11. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000003b839ca1 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000003b839784 13. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acdc84 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae66ecb 15. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 21. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:13.829825 [ 3655 ] {504e6da2-525b-4fa9-81f7-f6dc1f9f2a1a::20000101_1_1_0_5} MutatePlainMergeTreeTask: Code: 6. DB::Exception: Cannot parse string 'a' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 3'. (CANNOT_PARSE_TEXT) (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:13.832154 [ 3655 ] {504e6da2-525b-4fa9-81f7-f6dc1f9f2a1a::20000101_1_1_0_5} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 6. DB::Exception: Cannot parse string 'a' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 3'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x00000000086ed802 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000885710a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008832c1f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d57db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffeaa 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a24ade 11. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000003b839ca1 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000003b839784 13. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acdc84 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae66ecb 15. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 21. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:13.841135 [ 3681 ] {} test_15.r1 (a9e12f64-7d79-4642-a352-4087db67ff97): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr3&part=all_33_33_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:13.850951 [ 3680 ] {} test_15.r5 (1b626045-cf30-44b2-91f1-3165d43b86e1): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr3&part=all_34_34_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:13.852449 [ 3682 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr3&part=all_34_34_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:13.852954 [ 3677 ] {} test_15.r1 (a9e12f64-7d79-4642-a352-4087db67ff97): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr3&part=all_34_34_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:13.853908 [ 3668 ] {} test_15.r4 (b8428b65-4036-49d1-a93a-c7c1bd72c4c3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr3&part=all_34_34_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:13.878343 [ 3679 ] {} test_15.r1 (a9e12f64-7d79-4642-a352-4087db67ff97): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr3&part=all_33_33_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:13.880656 [ 3673 ] {} test_15.r1 (a9e12f64-7d79-4642-a352-4087db67ff97): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr3&part=all_34_34_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:13.905654 [ 3894 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:34:14.207374 [ 7652 ] {8c8b0fd6-eae0-4c98-92c2-a2b0c77c847d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=753, jobs=723). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38880) (comment: 02725_start_stop_fetches.sh) (in query: INSERT INTO r3 SELECT rand()), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003ae9ffe4 7. ./build_docker/./src/Server/TCPHandler.cpp:621: DB::TCPHandler::runImpl() @ 0x000000003abd95ce 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 2025.10.23 23:34:14.211952 [ 7652 ] {8c8b0fd6-eae0-4c98-92c2-a2b0c77c847d} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=753, jobs=723). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003ae9ffe4 7. ./build_docker/./src/Server/TCPHandler.cpp:621: DB::TCPHandler::runImpl() @ 0x000000003abd95ce 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 2025.10.23 23:34:15.000821 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:34:15.499829 [ 3671 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr5&part=all_38_38_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:15.504071 [ 3674 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr5&part=all_37_37_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:15.530501 [ 3667 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr5&part=all_38_38_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:15.547246 [ 3679 ] {} test_15.r1 (a9e12f64-7d79-4642-a352-4087db67ff97): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr5&part=all_37_37_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:15.628551 [ 3656 ] {504e6da2-525b-4fa9-81f7-f6dc1f9f2a1a::20010101_2_2_0_6} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:15.629468 [ 6969 ] {ffdeab5f-a2d0-454e-8302-3fa5cc785666} executeQuery: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_6.txt' with part '20010101_2_2_0_5' reason: 'Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build))'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query. (UNFINISHED) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 00834_kill_mutation.sh) (in query: /* ddl_entry=query-0000000017 */ ALTER TABLE test_11.kill_mutation DELETE WHERE x = 1 SETTINGS mutations_sync = 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&) @ 0x0000000039c1c97f 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000039c1c6e5 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003a2fe259 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003a3016f5 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034866f33 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003485e550 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003395fc9e 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000033958fac 13. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ad726d 14. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a52a3c 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034861fe8 16. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003485e550 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 26. ? @ 0x00007f100c857ac3 27. ? @ 0x00007f100c8e9850 2025.10.23 23:34:15.631905 [ 3656 ] {504e6da2-525b-4fa9-81f7-f6dc1f9f2a1a::20010101_2_2_0_6} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6377 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:15.635089 [ 6969 ] {ffdeab5f-a2d0-454e-8302-3fa5cc785666} executeQuery: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_6.txt' with part '20010101_2_2_0_5' reason: 'Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build))'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query. (UNFINISHED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:55156) (comment: 00834_kill_mutation.sh) (in query: ALTER TABLE kill_mutation DELETE WHERE x = 1 SETTINGS mutations_sync = 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&) @ 0x0000000039c1c97f 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000039c1c6e5 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003a2fe259 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003a3016f5 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034866f33 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003485e550 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003395fc9e 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000033958fac 13. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ad726d 14. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a52a3c 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034861fe8 16. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003485e550 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 26. ? @ 0x00007f100c857ac3 27. ? @ 0x00007f100c8e9850 2025.10.23 23:34:15.637236 [ 6969 ] {ffdeab5f-a2d0-454e-8302-3fa5cc785666} TCPHandler: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_6.txt' with part '20010101_2_2_0_5' reason: 'Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build))'. 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&) @ 0x0000000039c1c97f 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000039c1c6e5 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003a2fe259 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003a3016f5 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034866f33 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003485e550 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003395fc9e 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000033958fac 13. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ad726d 14. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a52a3c 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034861fe8 16. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003485e550 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 26. ? @ 0x00007f100c857ac3 27. ? @ 0x00007f100c8e9850 2025.10.23 23:34:15.981868 [ 3678 ] {} test_15.r1 (a9e12f64-7d79-4642-a352-4087db67ff97): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 32. DB::Exception: Attempt to read after EOF, left to copy 221 bytes. (ATTEMPT_TO_READ_AFTER_EOF), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000a7e012a 4. ./build_docker/./src/IO/copyData.cpp:38: DB::(anonymous namespace)::copyDataImpl(DB::ReadBuffer&, DB::WriteBuffer&, bool, unsigned long, std::atomic const*, std::shared_ptr) @ 0x000000002021dafc 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, unsigned long, std::atomic const&, std::shared_ptr) @ 0x000000002021f1b9 6. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:756: DB::DataPartsExchange::Fetcher::downloadBaseOrProjectionPartToDisk(String const&, std::shared_ptr const&, DB::ReadWriteBufferFromHTTP&, std::function> (DB::IDataPartStorage&, String const&, unsigned long)>, DB::MergeTreeDataPartChecksums&, std::shared_ptr, bool) const @ 0x00000000393ad0f5 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000393a4112 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x0000000039392f28 9. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 14. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 17. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 18. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 19. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 24. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 26. ? @ 0x00007f100c857ac3 27. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:16.078195 [ 9433 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:34:16.158443 [ 3645 ] {} b8428b65-4036-49d1-a93a-c7c1bd72c4c3::all_0_41_5 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 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) @ 0x0000000039c89948 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000003999bfb7 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 @ 0x00000000399942f0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000039d15c04 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&) @ 0x0000000039d20399 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) @ 0x0000000039d1c606 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000396308a4 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x00000000396235dd 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000003963b3e0 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x00000000396504a0 19. ./src/Storages/MergeTree/MergeFromLogEntryTask.h:36: DB::MergeFromLogEntryTask::executeInnerTask() @ 0x0000000039605f46 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a02473e 21. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 26. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 28. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 30. ? @ 0x00007f100c857ac3 31. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:16.158910 [ 3645 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b8428b65-4036-49d1-a93a-c7c1bd72c4c3::all_0_41_5}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 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) @ 0x0000000039c89948 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000003999bfb7 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 @ 0x00000000399942f0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000039d15c04 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&) @ 0x0000000039d20399 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) @ 0x0000000039d1c606 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000396308a4 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x00000000396235dd 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000003963b3e0 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x00000000396504a0 19. ./src/Storages/MergeTree/MergeFromLogEntryTask.h:36: DB::MergeFromLogEntryTask::executeInnerTask() @ 0x0000000039605f46 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a02473e 21. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 26. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 28. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 30. ? @ 0x00007f100c857ac3 31. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:16.981070 [ 3677 ] {} test_15.r4 (b8428b65-4036-49d1-a93a-c7c1bd72c4c3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr2&part=all_46_46_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:16.983312 [ 3668 ] {} test_15.r1 (a9e12f64-7d79-4642-a352-4087db67ff97): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr2&part=all_46_46_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:17.025833 [ 9557 ] {e11059c9-abc6-4415-9d40-3a09f3268dff} executeQuery: Code: 469. DB::Exception: Constraint `b_constraint` for table test_r4k9y9r2.test_constraints (b1651c31-711e-4e6a-9eea-e84ccaf9f9ce) is violated at row 2. Expression: (b > 0). Column values: b = 0. (VIOLATED_CONSTRAINT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:55224) (comment: 00952_basic_constraints.sh) (in query: INSERT INTO test_constraints 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x0000000032780947 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000003b7c787e 5. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b82a9a9 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b82a4b6 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b829167 8. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003aea4e44 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000003aef2f19 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000003abf92aa 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9316 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:34:17.028904 [ 9557 ] {e11059c9-abc6-4415-9d40-3a09f3268dff} TCPHandler: Code: 469. DB::Exception: Constraint `b_constraint` for table test_r4k9y9r2.test_constraints (b1651c31-711e-4e6a-9eea-e84ccaf9f9ce) is violated at row 2. Expression: (b > 0). Column values: b = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x0000000032780947 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000003b7c787e 5. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b82a9a9 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b82a4b6 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b829167 8. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003aea4e44 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000003aef2f19 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000003abf92aa 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9316 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:34:17.120716 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:34:17.247057 [ 3669 ] {} test_15.r5 (1b626045-cf30-44b2-91f1-3165d43b86e1): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr4&part=all_0_41_5&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:17.253719 [ 3673 ] {} test_15.r5 (1b626045-cf30-44b2-91f1-3165d43b86e1): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr2&part=all_46_46_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:17.295980 [ 3681 ] {} test_15.r5 (1b626045-cf30-44b2-91f1-3165d43b86e1): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr2&part=all_46_46_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:17.315153 [ 3671 ] {} test_15.r5 (1b626045-cf30-44b2-91f1-3165d43b86e1): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr2&part=all_43_43_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:17.490906 [ 3673 ] {} test_15.r4 (b8428b65-4036-49d1-a93a-c7c1bd72c4c3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr2&part=all_46_46_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:17.560487 [ 3674 ] {} test_15.r1 (a9e12f64-7d79-4642-a352-4087db67ff97): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr2&part=all_46_46_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:17.562859 [ 3680 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr2&part=all_46_46_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:18.121435 [ 3680 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr5&part=all_48_48_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:18.146153 [ 3676 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr5&part=all_48_48_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:18.170246 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:34:18.242753 [ 3669 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_50_50_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:18.247582 [ 3678 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr4&part=all_48_48_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:18.312530 [ 3668 ] {} test_15.r5 (1b626045-cf30-44b2-91f1-3165d43b86e1): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_50_50_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:18.389136 [ 3679 ] {} test_15.r5 (1b626045-cf30-44b2-91f1-3165d43b86e1): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_50_50_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:18.473264 [ 3672 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_50_50_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:18.480829 [ 3674 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr5&part=all_48_48_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:18.491652 [ 3670 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_50_50_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:18.501028 [ 3671 ] {} test_15.r5 (1b626045-cf30-44b2-91f1-3165d43b86e1): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_51_51_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:18.601791 [ 3676 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_51_51_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:18.615721 [ 3680 ] {} test_15.r5 (1b626045-cf30-44b2-91f1-3165d43b86e1): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_50_50_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:18.626823 [ 3679 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr4&part=all_48_48_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:18.631980 [ 3678 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_51_51_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:18.645480 [ 3668 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_50_50_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:18.648534 [ 3672 ] {} test_15.r5 (1b626045-cf30-44b2-91f1-3165d43b86e1): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_51_51_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:18.659348 [ 3669 ] {} test_15.r5 (1b626045-cf30-44b2-91f1-3165d43b86e1): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_50_50_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:18.669522 [ 3680 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_50_50_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:18.679999 [ 3676 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_51_51_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:18.680638 [ 3667 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr4&part=all_48_48_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:18.713159 [ 3677 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr5&part=all_47_47_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:18.721434 [ 3671 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr5&part=all_48_48_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:18.724764 [ 3668 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_51_51_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:18.762061 [ 3670 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr4&part=all_49_49_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:18.810314 [ 3672 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_50_50_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:18.858301 [ 3676 ] {} test_15.r5 (1b626045-cf30-44b2-91f1-3165d43b86e1): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_51_51_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:18.871472 [ 3678 ] {} test_15.r5 (1b626045-cf30-44b2-91f1-3165d43b86e1): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_50_50_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:18.875003 [ 3667 ] {} test_15.r5 (1b626045-cf30-44b2-91f1-3165d43b86e1): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_51_51_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:19.007774 [ 3680 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr4&part=all_49_49_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:19.013208 [ 3674 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_50_50_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:19.014083 [ 3672 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr4&part=all_48_48_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:19.058452 [ 9557 ] {3486a279-09c1-4c36-984c-f03c660ccae6} executeQuery: Code: 57. DB::Exception: Table test_r4k9y9r2.test_constraints already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:55664) (comment: 00952_basic_constraints.sh) (in query: CREATE TABLE test_constraints (`a` UInt32, `b` UInt32, CONSTRAINT a_constraint CHECK a < 10, CONSTRAINT b_constraint CHECK b > 10) ENGINE = MergeTree ORDER BY a SETTINGS index_granularity = 43853, min_bytes_for_wide_part = 619688584, 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 = 253961452, compact_parts_max_bytes_to_buffer = 117663477, compact_parts_max_granules_to_buffer = 156, compact_parts_merge_max_bytes_to_prefetch_part = 30325643, merge_max_block_size = 17747, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 2969034790, vertical_merge_algorithm_min_rows_to_activate = 92456, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8397609667, index_granularity_bytes = 27751413, concurrent_part_removal_threshold = 14, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 88947, primary_key_compress_block_size = 87629), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:34:19.060037 [ 9557 ] {3486a279-09c1-4c36-984c-f03c660ccae6} TCPHandler: Code: 57. DB::Exception: Table test_r4k9y9r2.test_constraints already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:34:19.109886 [ 3673 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_51_51_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:19.120740 [ 3680 ] {} test_15.r1 (a9e12f64-7d79-4642-a352-4087db67ff97): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr4&part=all_54_54_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:19.123401 [ 3669 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr4&part=all_48_48_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:19.123585 [ 3677 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_51_51_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:19.144319 [ 3667 ] {} test_15.r5 (1b626045-cf30-44b2-91f1-3165d43b86e1): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_51_51_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:19.145179 [ 3670 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_50_50_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:19.147897 [ 3681 ] {} test_15.r5 (1b626045-cf30-44b2-91f1-3165d43b86e1): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_50_50_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:19.191971 [ 3682 ] {} test_15.r5 (1b626045-cf30-44b2-91f1-3165d43b86e1): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr4&part=all_54_54_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:19.202861 [ 3668 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_50_50_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:19.203458 [ 3676 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr4&part=all_54_54_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:19.271391 [ 6969 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:34:19.301344 [ 3649 ] {} 1b626045-cf30-44b2-91f1-3165d43b86e1::all_0_41_5 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr4&part=all_0_41_5&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:19.301622 [ 3643 ] {} 1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c::all_0_47_6 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_47_6&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:19.310113 [ 3649 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1b626045-cf30-44b2-91f1-3165d43b86e1::all_0_41_5}: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr4&part=all_0_41_5&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:19.310658 [ 3643 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c::all_0_47_6}: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_47_6&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:19.369434 [ 7652 ] {c22b5734-43e9-41e0-8519-576b618ce7bd} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=764, jobs=729). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:55718) (comment: 02725_start_stop_fetches.sh) (in query: INSERT INTO r4 SELECT rand()), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003ae9ffe4 7. ./build_docker/./src/Server/TCPHandler.cpp:621: DB::TCPHandler::runImpl() @ 0x000000003abd95ce 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 2025.10.23 23:34:19.371878 [ 7652 ] {c22b5734-43e9-41e0-8519-576b618ce7bd} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=764, 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003ae9ffe4 7. ./build_docker/./src/Server/TCPHandler.cpp:621: DB::TCPHandler::runImpl() @ 0x000000003abd95ce 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 2025.10.23 23:34:19.446990 [ 3669 ] {} test_15.r5 (1b626045-cf30-44b2-91f1-3165d43b86e1): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr4&part=all_54_54_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:19.449376 [ 3667 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr4&part=all_54_54_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:19.593959 [ 7760 ] {4c2e42c4-c02b-484a-8802-1a6b2e810585} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:55632) (comment: 01477_lc_in_merge_join_left_key.gen.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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000003159b57b 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337550f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e79fb4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:34:19.595191 [ 7760 ] {4c2e42c4-c02b-484a-8802-1a6b2e810585} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000003159b57b 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337550f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e79fb4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:34:20.122826 [ 3675 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr4&part=all_56_56_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:20.123885 [ 3682 ] {} test_15.r5 (1b626045-cf30-44b2-91f1-3165d43b86e1): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr4&part=all_56_56_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:20.155180 [ 3681 ] {} test_15.r5 (1b626045-cf30-44b2-91f1-3165d43b86e1): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr4&part=all_56_56_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:20.221142 [ 3672 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr4&part=all_56_56_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:20.319991 [ 6969 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:34:20.363647 [ 9453 ] {bfd2272f-34e4-481f-9f4b-51e4ac93310e} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:55670) (comment: 01225_drop_dictionary_as_table.sql) (in query: DROP TABLE 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349417ab 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:34:20.464112 [ 9453 ] {bfd2272f-34e4-481f-9f4b-51e4ac93310e} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349417ab 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:34:20.470280 [ 3669 ] {} test_15.r4 (b8428b65-4036-49d1-a93a-c7c1bd72c4c3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr5&part=all_55_55_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:20.591118 [ 7760 ] {fcc3851c-c20d-4f6c-a1a5-4f3eab80cedb} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:55778) (comment: 02725_start_stop_fetches.sh) (in query: INSERT INTO r2 SELECT rand()), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 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*) @ 0x000000003aea17d9 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:34:20.594997 [ 7760 ] {fcc3851c-c20d-4f6c-a1a5-4f3eab80cedb} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 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*) @ 0x000000003aea17d9 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:34:21.037299 [ 3654 ] {} 37341e51-1a17-4c44-9987-141583b579a2::all_0_58_8 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 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) @ 0x0000000039c89948 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000003999bfb7 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 @ 0x00000000399942f0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000039d15c04 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&) @ 0x0000000039d20399 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) @ 0x0000000039d1c606 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000396308a4 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x00000000396235dd 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000003963b3e0 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x00000000396504a0 19. ./src/Storages/MergeTree/MergeFromLogEntryTask.h:36: DB::MergeFromLogEntryTask::executeInnerTask() @ 0x0000000039605f46 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a02473e 21. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 26. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 28. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 30. ? @ 0x00007f100c857ac3 31. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:21.037776 [ 3654 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {37341e51-1a17-4c44-9987-141583b579a2::all_0_58_8}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 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) @ 0x0000000039c89948 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000003999bfb7 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 @ 0x00000000399942f0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000039d15c04 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&) @ 0x0000000039d20399 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) @ 0x0000000039d1c606 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000396308a4 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x00000000396235dd 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000003963b3e0 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x00000000396504a0 19. ./src/Storages/MergeTree/MergeFromLogEntryTask.h:36: DB::MergeFromLogEntryTask::executeInnerTask() @ 0x0000000039605f46 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a02473e 21. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 26. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 28. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 30. ? @ 0x00007f100c857ac3 31. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:21.097309 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:34:21.433322 [ 9558 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:34:21.582924 [ 3671 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_60_60_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:21.584624 [ 3676 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_60_60_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:21.584736 [ 3668 ] {} test_15.r5 (1b626045-cf30-44b2-91f1-3165d43b86e1): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_60_60_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:21.726391 [ 3670 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr2&part=all_61_61_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:21.734509 [ 3667 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_60_60_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:21.735461 [ 3672 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_60_60_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:21.738696 [ 3669 ] {} test_15.r5 (1b626045-cf30-44b2-91f1-3165d43b86e1): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr2&part=all_61_61_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:21.740663 [ 3675 ] {} test_15.r5 (1b626045-cf30-44b2-91f1-3165d43b86e1): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_60_60_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:21.939466 [ 3676 ] {} test_15.r5 (1b626045-cf30-44b2-91f1-3165d43b86e1): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr2&part=all_61_61_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:21.942833 [ 3670 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_60_60_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:21.948652 [ 3674 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr2&part=all_62_62_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:21.950122 [ 3680 ] {} test_15.r5 (1b626045-cf30-44b2-91f1-3165d43b86e1): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr2&part=all_62_62_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:21.951485 [ 3678 ] {} test_15.r5 (1b626045-cf30-44b2-91f1-3165d43b86e1): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_60_60_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:21.953044 [ 3682 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr2&part=all_61_61_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:21.954174 [ 3681 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_60_60_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:22.045000 [ 3673 ] {} test_15.r4 (b8428b65-4036-49d1-a93a-c7c1bd72c4c3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_58_8&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:22.050968 [ 3670 ] {} test_15.r4 (b8428b65-4036-49d1-a93a-c7c1bd72c4c3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr2&part=all_62_62_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:22.053044 [ 3680 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_60_60_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:22.053391 [ 3667 ] {} test_15.r4 (b8428b65-4036-49d1-a93a-c7c1bd72c4c3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_60_60_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:22.053567 [ 3677 ] {} test_15.r4 (b8428b65-4036-49d1-a93a-c7c1bd72c4c3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr2&part=all_61_61_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:22.056805 [ 3671 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr2&part=all_61_61_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:22.098437 [ 3674 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr2&part=all_62_62_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:22.209753 [ 3673 ] {} test_15.r5 (1b626045-cf30-44b2-91f1-3165d43b86e1): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr2&part=all_62_62_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:22.224461 [ 3658 ] {} b8428b65-4036-49d1-a93a-c7c1bd72c4c3::all_0_58_8 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr2&part=all_0_58_8&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:22.224883 [ 3658 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b8428b65-4036-49d1-a93a-c7c1bd72c4c3::all_0_58_8}: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr2&part=all_0_58_8&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:22.227629 [ 3677 ] {} test_15.r4 (b8428b65-4036-49d1-a93a-c7c1bd72c4c3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr2&part=all_62_62_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:22.234712 [ 3675 ] {} test_15.r5 (1b626045-cf30-44b2-91f1-3165d43b86e1): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr2&part=all_61_61_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:22.238523 [ 3680 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr2&part=all_61_61_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:22.355920 [ 3681 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr2&part=all_62_62_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:22.357093 [ 3678 ] {} test_15.r4 (b8428b65-4036-49d1-a93a-c7c1bd72c4c3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr2&part=all_61_61_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:22.445366 [ 3677 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr2&part=all_62_62_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:22.451197 [ 3680 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr2&part=all_61_61_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:22.468622 [ 3678 ] {} test_15.r5 (1b626045-cf30-44b2-91f1-3165d43b86e1): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr2&part=all_62_62_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:22.489717 [ 3673 ] {} test_15.r5 (1b626045-cf30-44b2-91f1-3165d43b86e1): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr2&part=all_61_61_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:22.506160 [ 3682 ] {} test_15.r4 (b8428b65-4036-49d1-a93a-c7c1bd72c4c3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr2&part=all_61_61_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:22.522947 [ 3675 ] {} test_15.r4 (b8428b65-4036-49d1-a93a-c7c1bd72c4c3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr2&part=all_62_62_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:22.530345 [ 3668 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr2&part=all_61_61_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:22.535434 [ 3678 ] {} test_15.r5 (1b626045-cf30-44b2-91f1-3165d43b86e1): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr2&part=all_61_61_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:22.540806 [ 9558 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:34:22.573445 [ 3672 ] {} test_15.r5 (1b626045-cf30-44b2-91f1-3165d43b86e1): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr2&part=all_62_62_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:22.580167 [ 3667 ] {} test_15.r4 (b8428b65-4036-49d1-a93a-c7c1bd72c4c3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr2&part=all_62_62_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:22.582671 [ 3682 ] {} test_15.r4 (b8428b65-4036-49d1-a93a-c7c1bd72c4c3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr2&part=all_61_61_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:23.229187 [ 3680 ] {} test_15.r5 (1b626045-cf30-44b2-91f1-3165d43b86e1): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_68_68_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:23.229366 [ 3678 ] {} test_15.r4 (b8428b65-4036-49d1-a93a-c7c1bd72c4c3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_68_68_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:23.241165 [ 3670 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_68_68_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:23.327200 [ 9453 ] {55331fac-d450-47cc-acef-209b3f76b989} executeQuery: Code: 387. DB::Exception: Dictionary test_3.dict already exists. (DICTIONARY_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56144) (comment: 02910_rocksdb_optimize.sql) (in query: CREATE TABLE dict (key UInt64, value String) ENGINE = EmbeddedRocksDB PRIMARY KEY 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1614: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb1a3 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:34:23.335765 [ 9453 ] {55331fac-d450-47cc-acef-209b3f76b989} TCPHandler: Code: 387. DB::Exception: Dictionary test_3.dict already exists. (DICTIONARY_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1614: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb1a3 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:34:23.390736 [ 3675 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_68_68_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:23.525347 [ 3676 ] {} test_15.r5 (1b626045-cf30-44b2-91f1-3165d43b86e1): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_68_68_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:23.538185 [ 3673 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_68_68_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:23.544551 [ 3672 ] {} test_15.r4 (b8428b65-4036-49d1-a93a-c7c1bd72c4c3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_68_68_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:23.553554 [ 3678 ] {} test_15.r5 (1b626045-cf30-44b2-91f1-3165d43b86e1): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_68_68_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:23.562763 [ 3674 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_68_68_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:23.670806 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:34:23.682099 [ 3894 ] {5890909c-3030-4c7e-a45c-82dadfb96e50} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56266) (comment: 00952_basic_constraints.sh) (in query: SELECT * FROM test_constraints;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:34:23.685810 [ 3894 ] {5890909c-3030-4c7e-a45c-82dadfb96e50} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:34:23.750392 [ 3667 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_68_68_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:23.834130 [ 3682 ] {} test_15.r5 (1b626045-cf30-44b2-91f1-3165d43b86e1): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_68_68_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:23.870872 [ 3681 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_68_68_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:23.876905 [ 3670 ] {} test_15.r4 (b8428b65-4036-49d1-a93a-c7c1bd72c4c3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_68_68_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:23.885943 [ 3675 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_68_68_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:23.896331 [ 3676 ] {} test_15.r4 (b8428b65-4036-49d1-a93a-c7c1bd72c4c3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_68_68_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:23.899843 [ 3667 ] {} test_15.r5 (1b626045-cf30-44b2-91f1-3165d43b86e1): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_68_68_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:23.901266 [ 3680 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_68_68_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:23.922198 [ 3672 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_68_68_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:24.118776 [ 3670 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_68_68_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:24.138982 [ 3667 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_68_68_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:24.150944 [ 3671 ] {} test_15.r4 (b8428b65-4036-49d1-a93a-c7c1bd72c4c3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:24.160120 [ 3673 ] {} test_15.r5 (1b626045-cf30-44b2-91f1-3165d43b86e1): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:24.162003 [ 3658 ] {} 37341e51-1a17-4c44-9987-141583b579a2::all_0_70_10 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:24.162034 [ 3675 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:24.162514 [ 3658 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {37341e51-1a17-4c44-9987-141583b579a2::all_0_70_10}: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:24.166387 [ 3681 ] {} test_15.r4 (b8428b65-4036-49d1-a93a-c7c1bd72c4c3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:24.166560 [ 3669 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:24.167166 [ 3668 ] {} test_15.r5 (1b626045-cf30-44b2-91f1-3165d43b86e1): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:24.177569 [ 3677 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:24.419621 [ 3671 ] {} test_15.r5 (1b626045-cf30-44b2-91f1-3165d43b86e1): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:24.420008 [ 3644 ] {} 1b626045-cf30-44b2-91f1-3165d43b86e1::all_0_70_10 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:24.420859 [ 3644 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1b626045-cf30-44b2-91f1-3165d43b86e1::all_0_70_10}: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:24.433684 [ 3676 ] {} test_15.r5 (1b626045-cf30-44b2-91f1-3165d43b86e1): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:24.440320 [ 3678 ] {} test_15.r5 (1b626045-cf30-44b2-91f1-3165d43b86e1): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:24.721335 [ 6969 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:34:24.755924 [ 9433 ] {6b3fd472-4906-419c-a217-ef1c24f08c62} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=8, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56140) (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x0000000030ccfa9e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030ccf300 8. ./contrib/llvm-project/libcxx/include/future:1237: DB::TaskTracker::add(std::function&&) @ 0x0000000030efea8f 9. ./build_docker/./src/IO/WriteBufferFromS3.cpp:0: DB::WriteBufferFromS3::makeSinglepartUpload(DB::WriteBufferFromS3::PartData&&) @ 0x0000000030ebabb9 10. ./build_docker/./src/IO/WriteBufferFromS3.cpp:180: DB::WriteBufferFromS3::preFinalize() @ 0x0000000030eb92e2 11. ./build_docker/./src/IO/WriteBufferFromFileDecorator.cpp:0: DB::WriteBufferFromFileDecorator::preFinalize() @ 0x0000000032fc63cf 12. ./build_docker/./src/IO/WriteBufferFromFileDecorator.cpp:0: DB::WriteBufferFromFileDecorator::preFinalize() @ 0x0000000032fc63cf 13. ./contrib/llvm-project/libcxx/include/vector:1629: DB::MergedBlockOutputStream::finalizePartOnDisk(std::shared_ptr const&, DB::MergeTreeDataPartChecksums&) @ 0x0000000039e4ac0c 14. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:0: DB::MergedBlockOutputStream::finalizePartAsync(std::shared_ptr const&, bool, DB::NamesAndTypesList const*, DB::MergeTreeDataPartChecksums*, std::vector>*) @ 0x0000000039e43ce2 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:0: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039f2314c 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:444: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039f1688a 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a200100 18. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bb51384 19. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b82a9a9 20. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b82a4b6 21. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b829167 22. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003aea4e44 25. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000003aef2f19 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000003abf92aa 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9316 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 2025.10.23 23:34:24.757385 [ 9433 ] {6b3fd472-4906-419c-a217-ef1c24f08c62} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=8, 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x0000000030ccfa9e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030ccf300 8. ./contrib/llvm-project/libcxx/include/future:1237: DB::TaskTracker::add(std::function&&) @ 0x0000000030efea8f 9. ./build_docker/./src/IO/WriteBufferFromS3.cpp:0: DB::WriteBufferFromS3::makeSinglepartUpload(DB::WriteBufferFromS3::PartData&&) @ 0x0000000030ebabb9 10. ./build_docker/./src/IO/WriteBufferFromS3.cpp:180: DB::WriteBufferFromS3::preFinalize() @ 0x0000000030eb92e2 11. ./build_docker/./src/IO/WriteBufferFromFileDecorator.cpp:0: DB::WriteBufferFromFileDecorator::preFinalize() @ 0x0000000032fc63cf 12. ./build_docker/./src/IO/WriteBufferFromFileDecorator.cpp:0: DB::WriteBufferFromFileDecorator::preFinalize() @ 0x0000000032fc63cf 13. ./contrib/llvm-project/libcxx/include/vector:1629: DB::MergedBlockOutputStream::finalizePartOnDisk(std::shared_ptr const&, DB::MergeTreeDataPartChecksums&) @ 0x0000000039e4ac0c 14. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:0: DB::MergedBlockOutputStream::finalizePartAsync(std::shared_ptr const&, bool, DB::NamesAndTypesList const*, DB::MergeTreeDataPartChecksums*, std::vector>*) @ 0x0000000039e43ce2 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:0: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039f2314c 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:444: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039f1688a 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a200100 18. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bb51384 19. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b82a9a9 20. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b82a4b6 21. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b829167 22. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003aea4e44 25. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000003aef2f19 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000003abf92aa 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9316 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 2025.10.23 23:34:24.886771 [ 3675 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:24.888931 [ 3648 ] {} 37341e51-1a17-4c44-9987-141583b579a2::all_0_70_10 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:24.889839 [ 3648 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {37341e51-1a17-4c44-9987-141583b579a2::all_0_70_10}: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:24.900396 [ 3681 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:24.963469 [ 9434 ] {b6f8a09f-b251-4de2-ba7b-941535c038bf} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:56324). (NETWORK_ERROR) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56324) (comment: 02725_start_stop_fetches.sh) (in query: INSERT INTO r1 SELECT rand()), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c6938 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileEvents() @ 0x000000003ac13c7b 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd96e0 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:34:24.965047 [ 9434 ] {b6f8a09f-b251-4de2-ba7b-941535c038bf} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:56324). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c6938 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000003ac2dd9a 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x000000003abff96a 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9aa8 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:24.965297 [ 9434 ] {b6f8a09f-b251-4de2-ba7b-941535c038bf} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:56324). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c6938 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileEvents() @ 0x000000003ac13c7b 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd96e0 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:34:24.965760 [ 9434 ] {b6f8a09f-b251-4de2-ba7b-941535c038bf} TCPHandler: Client has gone away. 2025.10.23 23:34:24.980977 [ 3669 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:24.981496 [ 3670 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:25.054162 [ 3645 ] {} 1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c::all_0_70_10 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:25.054681 [ 3645 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c::all_0_70_10}: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:25.067295 [ 3682 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:25.067594 [ 3677 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:25.292394 [ 3653 ] {} 1b626045-cf30-44b2-91f1-3165d43b86e1::all_0_70_10 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:25.293147 [ 3653 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1b626045-cf30-44b2-91f1-3165d43b86e1::all_0_70_10}: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:25.294211 [ 3673 ] {} test_15.r4 (b8428b65-4036-49d1-a93a-c7c1bd72c4c3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:25.294394 [ 3676 ] {} test_15.r5 (1b626045-cf30-44b2-91f1-3165d43b86e1): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:25.298291 [ 3652 ] {} b8428b65-4036-49d1-a93a-c7c1bd72c4c3::all_0_70_10 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:25.298895 [ 3652 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b8428b65-4036-49d1-a93a-c7c1bd72c4c3::all_0_70_10}: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:25.306456 [ 3678 ] {} test_15.r5 (1b626045-cf30-44b2-91f1-3165d43b86e1): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:25.308903 [ 3675 ] {} test_15.r4 (b8428b65-4036-49d1-a93a-c7c1bd72c4c3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:25.312211 [ 3681 ] {} test_15.r4 (b8428b65-4036-49d1-a93a-c7c1bd72c4c3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:25.706281 [ 3646 ] {} 1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c::all_0_70_10 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:25.706884 [ 3646 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c::all_0_70_10}: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:25.710178 [ 3670 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:25.752905 [ 3667 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:25.784820 [ 3658 ] {} 37341e51-1a17-4c44-9987-141583b579a2::all_0_70_10 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:25.785334 [ 3658 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {37341e51-1a17-4c44-9987-141583b579a2::all_0_70_10}: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:25.788071 [ 3677 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:25.809311 [ 7760 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:34:26.022597 [ 3644 ] {} b8428b65-4036-49d1-a93a-c7c1bd72c4c3::all_0_70_10 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:26.022644 [ 3673 ] {} test_15.r4 (b8428b65-4036-49d1-a93a-c7c1bd72c4c3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:26.023224 [ 3644 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b8428b65-4036-49d1-a93a-c7c1bd72c4c3::all_0_70_10}: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:26.033838 [ 3674 ] {} test_15.r4 (b8428b65-4036-49d1-a93a-c7c1bd72c4c3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:26.101849 [ 3680 ] {} test_15.r5 (1b626045-cf30-44b2-91f1-3165d43b86e1): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:26.105854 [ 3675 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:26.107905 [ 3648 ] {} 1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c::all_0_70_10 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:26.108544 [ 3648 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c::all_0_70_10}: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:26.109354 [ 3643 ] {} 1b626045-cf30-44b2-91f1-3165d43b86e1::all_0_70_10 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:26.109883 [ 3643 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1b626045-cf30-44b2-91f1-3165d43b86e1::all_0_70_10}: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:26.117265 [ 3676 ] {} test_15.r4 (b8428b65-4036-49d1-a93a-c7c1bd72c4c3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:26.122296 [ 3670 ] {} test_15.r5 (1b626045-cf30-44b2-91f1-3165d43b86e1): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:26.124275 [ 3682 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:26.125509 [ 3681 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:26.127995 [ 3667 ] {} test_15.r5 (1b626045-cf30-44b2-91f1-3165d43b86e1): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:26.560090 [ 3674 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:26.560325 [ 3649 ] {} 1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c::all_0_70_10 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:26.561004 [ 3649 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c::all_0_70_10}: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:26.571918 [ 3680 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:26.572421 [ 3669 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:26.768762 [ 3643 ] {} b8428b65-4036-49d1-a93a-c7c1bd72c4c3::all_0_70_10 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:26.769293 [ 3643 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b8428b65-4036-49d1-a93a-c7c1bd72c4c3::all_0_70_10}: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:26.786724 [ 3671 ] {} test_15.r5 (1b626045-cf30-44b2-91f1-3165d43b86e1): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:26.789426 [ 3670 ] {} test_15.r4 (b8428b65-4036-49d1-a93a-c7c1bd72c4c3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:26.789430 [ 3645 ] {} 1b626045-cf30-44b2-91f1-3165d43b86e1::all_0_70_10 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:26.790145 [ 3645 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1b626045-cf30-44b2-91f1-3165d43b86e1::all_0_70_10}: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:26.790486 [ 3676 ] {} test_15.r4 (b8428b65-4036-49d1-a93a-c7c1bd72c4c3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:26.801825 [ 3672 ] {} test_15.r5 (1b626045-cf30-44b2-91f1-3165d43b86e1): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:26.803482 [ 3673 ] {} test_15.r5 (1b626045-cf30-44b2-91f1-3165d43b86e1): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:26.854170 [ 10275 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:34:26.896558 [ 3674 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:26.903156 [ 3667 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:27.164826 [ 3654 ] {} 1b626045-cf30-44b2-91f1-3165d43b86e1::all_0_70_10 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:27.165893 [ 3654 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1b626045-cf30-44b2-91f1-3165d43b86e1::all_0_70_10}: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:27.167000 [ 3669 ] {} test_15.r5 (1b626045-cf30-44b2-91f1-3165d43b86e1): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:27.679324 [ 3670 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:27.689362 [ 3650 ] {} 1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c::all_0_70_10 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:27.690239 [ 3650 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c::all_0_70_10}: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:27.700297 [ 3681 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:27.703482 [ 3676 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:27.840774 [ 3678 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:27.841629 [ 3674 ] {} test_15.r4 (b8428b65-4036-49d1-a93a-c7c1bd72c4c3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:27.846906 [ 3644 ] {} 37341e51-1a17-4c44-9987-141583b579a2::all_0_70_10 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:27.847468 [ 3644 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {37341e51-1a17-4c44-9987-141583b579a2::all_0_70_10}: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:27.860624 [ 3675 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:27.860933 [ 3667 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:27.931508 [ 9434 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:34:27.934167 [ 7760 ] {f4e0f169-4e88-4ec8-ae01-77c16e91973d} executeQuery: Code: 241. DB::Exception: Memory tracker (for query): fault injected. Would use 0.00 B (attempt to allocate chunk of 0 bytes), maximum: 9.31 GiB: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44718) (comment: 00994_table_function_numbers_mt.sql) (in query: SELECT min(number), max(number), sum(number) FROM numbers(10000000, 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, String&&, long&, String&&) @ 0x000000002009baa7 4. ./build_docker/./src/Common/MemoryTracker.cpp:284: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002009a3d3 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099272 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:85: CurrentMemoryTracker::check() @ 0x000000001ff7c865 7. ./build_docker/./src/Interpreters/Aggregator.cpp:0: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000033b55571 8. ./build_docker/./src/Interpreters/Aggregator.cpp:0: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000033b6c296 9. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:692: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003b7a34d4 10. ./src/Common/CollectionOfDerived.h:28: DB::AggregatingTransform::work() @ 0x000000003b797254 11. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 15. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:34:27.936320 [ 7760 ] {f4e0f169-4e88-4ec8-ae01-77c16e91973d} TCPHandler: Code: 241. DB::Exception: Memory tracker (for query): fault injected. Would use 0.00 B (attempt to allocate chunk of 0 bytes), maximum: 9.31 GiB: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, String&&, long&, String&&) @ 0x000000002009baa7 4. ./build_docker/./src/Common/MemoryTracker.cpp:284: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002009a3d3 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099272 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:85: CurrentMemoryTracker::check() @ 0x000000001ff7c865 7. ./build_docker/./src/Interpreters/Aggregator.cpp:0: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000033b55571 8. ./build_docker/./src/Interpreters/Aggregator.cpp:0: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000033b6c296 9. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:692: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003b7a34d4 10. ./src/Common/CollectionOfDerived.h:28: DB::AggregatingTransform::work() @ 0x000000003b797254 11. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 15. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:34:27.942753 [ 3657 ] {} b8428b65-4036-49d1-a93a-c7c1bd72c4c3::all_0_70_10 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:27.943298 [ 3657 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b8428b65-4036-49d1-a93a-c7c1bd72c4c3::all_0_70_10}: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:27.954695 [ 3671 ] {} test_15.r4 (b8428b65-4036-49d1-a93a-c7c1bd72c4c3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:28.013998 [ 3682 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:28.015125 [ 3677 ] {} test_15.r4 (b8428b65-4036-49d1-a93a-c7c1bd72c4c3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:28.017922 [ 3655 ] {} 1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c::all_0_70_10 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:28.018450 [ 3655 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c::all_0_70_10}: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:28.121966 [ 3676 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:28.122176 [ 3679 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:28.122890 [ 3680 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:28.124778 [ 3673 ] {} test_15.r5 (1b626045-cf30-44b2-91f1-3165d43b86e1): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:28.125660 [ 3678 ] {} test_15.r5 (1b626045-cf30-44b2-91f1-3165d43b86e1): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:28.129354 [ 3647 ] {} 37341e51-1a17-4c44-9987-141583b579a2::all_0_70_10 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:28.130155 [ 3647 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {37341e51-1a17-4c44-9987-141583b579a2::all_0_70_10}: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:28.141504 [ 3670 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:28.144563 [ 3671 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:28.147611 [ 7760 ] {13b46ce7-ddd9-42b5-8205-45d62232f89a} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=29, jobs=29). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44814) (comment: 02253_empty_part_checksums.sh) (in query: check table rmt), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6377 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 2025.10.23 23:34:28.148513 [ 6969 ] {3ea10ec3-2b52-49c4-a05c-a9d178d34383} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44672) (comment: 01125_generate_random_qoega.sql) (in query: SELECT count(), sum(cityHash64(*)) FROM mass_table_117;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202dea34 6. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039a5dbc5 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003bf2b229 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bf26bba 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003bf26345 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bf3d5b9 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2045: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf42fe0 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be48783 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003beb6da5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034cf5e6d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034cf5881 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:34:28.150128 [ 6969 ] {3ea10ec3-2b52-49c4-a05c-a9d178d34383} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202dea34 6. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039a5dbc5 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003bf2b229 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bf26bba 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003bf26345 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bf3d5b9 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2045: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf42fe0 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be48783 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003beb6da5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034cf5e6d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034cf5881 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:34:28.150843 [ 7760 ] {13b46ce7-ddd9-42b5-8205-45d62232f89a} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=29, jobs=29). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6377 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 2025.10.23 23:34:28.272585 [ 9678 ] {c146492d-3fc2-46f2-a8f5-7d606d0bbb31} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48562) (comment: 01125_generate_random_qoega.sql) (in query: DROP DATABASE IF EXISTS test_xqmez7yz ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:34:28.273910 [ 9678 ] {c146492d-3fc2-46f2-a8f5-7d606d0bbb31} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:28.288517 [ 10275 ] {661457a4-c744-45bc-b889-7a88cc1545a3} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48566) (comment: 01125_generate_random_qoega.sql) (in query: DROP DATABASE IF EXISTS test_xqmez7yz ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:34:28.290307 [ 10275 ] {661457a4-c744-45bc-b889-7a88cc1545a3} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:28.304416 [ 9558 ] {359337f8-1167-4694-a548-4841f56e877f} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48568) (comment: 01125_generate_random_qoega.sql) (in query: DROP DATABASE IF EXISTS test_xqmez7yz ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:34:28.306228 [ 9558 ] {359337f8-1167-4694-a548-4841f56e877f} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:28.319238 [ 10275 ] {79720b52-4845-46b7-b590-94a185ba424c} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48572) (comment: 01125_generate_random_qoega.sql) (in query: DROP DATABASE IF EXISTS test_xqmez7yz ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:34:28.321070 [ 10275 ] {79720b52-4845-46b7-b590-94a185ba424c} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:28.334233 [ 9558 ] {06b64d86-19d7-451d-bcf9-7f519ef1476f} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48576) (comment: 01125_generate_random_qoega.sql) (in query: DROP DATABASE IF EXISTS test_xqmez7yz ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:34:28.335873 [ 9558 ] {06b64d86-19d7-451d-bcf9-7f519ef1476f} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:28.402970 [ 3677 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:28.454160 [ 3653 ] {} 1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c::all_0_70_10 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:28.454695 [ 3653 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c::all_0_70_10}: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:28.627271 [ 3674 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:28.628513 [ 3676 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:28.687801 [ 3680 ] {} test_15.r4 (b8428b65-4036-49d1-a93a-c7c1bd72c4c3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:28.688373 [ 3652 ] {} b8428b65-4036-49d1-a93a-c7c1bd72c4c3::all_0_70_10 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:28.689197 [ 3652 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b8428b65-4036-49d1-a93a-c7c1bd72c4c3::all_0_70_10}: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:28.698712 [ 3669 ] {} test_15.r4 (b8428b65-4036-49d1-a93a-c7c1bd72c4c3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:28.706676 [ 3673 ] {} test_15.r4 (b8428b65-4036-49d1-a93a-c7c1bd72c4c3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:28.801302 [ 3656 ] {} 1b626045-cf30-44b2-91f1-3165d43b86e1::all_0_70_10 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:28.801854 [ 3656 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1b626045-cf30-44b2-91f1-3165d43b86e1::all_0_70_10}: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:28.804995 [ 3670 ] {} test_15.r5 (1b626045-cf30-44b2-91f1-3165d43b86e1): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:28.817498 [ 3682 ] {} test_15.r5 (1b626045-cf30-44b2-91f1-3165d43b86e1): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:28.826992 [ 3650 ] {} 37341e51-1a17-4c44-9987-141583b579a2::all_0_70_10 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:28.827524 [ 3650 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {37341e51-1a17-4c44-9987-141583b579a2::all_0_70_10}: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:28.830722 [ 3681 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:28.993189 [ 3644 ] {} 1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c::all_0_70_10 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:28.994042 [ 3644 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c::all_0_70_10}: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:29.078729 [ 3679 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:29.166082 [ 10275 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:34:29.177700 [ 7760 ] {acb64bbe-8a69-42f9-81fb-6b364cc2b99f} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48596) (comment: 02922_deduplication_with_zero_copy.sh) (in query: DROP DATABASE IF EXISTS test_eboyeecx ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:34:29.179273 [ 7760 ] {acb64bbe-8a69-42f9-81fb-6b364cc2b99f} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:29.233957 [ 3676 ] {} test_15.r4 (b8428b65-4036-49d1-a93a-c7c1bd72c4c3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:29.239367 [ 3657 ] {} b8428b65-4036-49d1-a93a-c7c1bd72c4c3::all_0_70_10 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:29.240543 [ 3657 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b8428b65-4036-49d1-a93a-c7c1bd72c4c3::all_0_70_10}: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:29.282923 [ 3675 ] {} test_15.r4 (b8428b65-4036-49d1-a93a-c7c1bd72c4c3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:29.296224 [ 9558 ] {9a4497a6-c3fb-4320-86b4-f944b9744b79} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48606) (comment: 02922_deduplication_with_zero_copy.sh) (in query: DROP DATABASE IF EXISTS test_eboyeecx ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:34:29.298675 [ 9558 ] {9a4497a6-c3fb-4320-86b4-f944b9744b79} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:29.462634 [ 3680 ] {} test_15.r4 (b8428b65-4036-49d1-a93a-c7c1bd72c4c3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:29.474434 [ 3655 ] {} 1b626045-cf30-44b2-91f1-3165d43b86e1::all_0_70_10 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:29.475337 [ 3655 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1b626045-cf30-44b2-91f1-3165d43b86e1::all_0_70_10}: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:29.475678 [ 3669 ] {} test_15.r5 (1b626045-cf30-44b2-91f1-3165d43b86e1): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:29.612129 [ 3670 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:29.725903 [ 3647 ] {} 1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c::all_0_70_10 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:29.726509 [ 3647 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c::all_0_70_10}: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:29.738713 [ 3677 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:29.773710 [ 3671 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:29.911442 [ 3674 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:29.911484 [ 3679 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:29.967335 [ 3653 ] {} 1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c::all_0_70_10 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:29.968044 [ 3678 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:29.968157 [ 3653 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c::all_0_70_10}: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:29.981026 [ 3673 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:29.981405 [ 3680 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:30.037899 [ 3670 ] {} test_15.r5 (1b626045-cf30-44b2-91f1-3165d43b86e1): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:30.122885 [ 3682 ] {} test_15.r5 (1b626045-cf30-44b2-91f1-3165d43b86e1): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:30.314560 [ 9433 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:34:30.320513 [ 3652 ] {} 1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c::all_0_70_10 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:30.320923 [ 3652 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c::all_0_70_10}: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:30.395455 [ 3674 ] {} test_15.r4 (b8428b65-4036-49d1-a93a-c7c1bd72c4c3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:30.397209 [ 3676 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:30.397906 [ 3656 ] {} b8428b65-4036-49d1-a93a-c7c1bd72c4c3::all_0_70_10 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:30.398441 [ 3656 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b8428b65-4036-49d1-a93a-c7c1bd72c4c3::all_0_70_10}: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:30.400818 [ 3649 ] {} 37341e51-1a17-4c44-9987-141583b579a2::all_0_70_10 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:30.401336 [ 3649 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {37341e51-1a17-4c44-9987-141583b579a2::all_0_70_10}: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:30.406841 [ 3678 ] {} test_15.r4 (b8428b65-4036-49d1-a93a-c7c1bd72c4c3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:30.409806 [ 3675 ] {} test_15.r4 (b8428b65-4036-49d1-a93a-c7c1bd72c4c3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:30.412459 [ 3673 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:30.415273 [ 3669 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:30.448665 [ 3671 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:30.478424 [ 3681 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:30.773579 [ 3674 ] {} test_15.r5 (1b626045-cf30-44b2-91f1-3165d43b86e1): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:30.776482 [ 3644 ] {} 1b626045-cf30-44b2-91f1-3165d43b86e1::all_0_70_10 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:30.777004 [ 3644 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1b626045-cf30-44b2-91f1-3165d43b86e1::all_0_70_10}: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:30.786998 [ 3668 ] {} test_15.r5 (1b626045-cf30-44b2-91f1-3165d43b86e1): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:30.790520 [ 3676 ] {} test_15.r5 (1b626045-cf30-44b2-91f1-3165d43b86e1): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:30.886335 [ 3657 ] {} b8428b65-4036-49d1-a93a-c7c1bd72c4c3::all_0_70_10 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:30.886473 [ 3675 ] {} test_15.r4 (b8428b65-4036-49d1-a93a-c7c1bd72c4c3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:30.886882 [ 3657 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b8428b65-4036-49d1-a93a-c7c1bd72c4c3::all_0_70_10}: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:30.981576 [ 3673 ] {} test_15.r4 (b8428b65-4036-49d1-a93a-c7c1bd72c4c3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:30.983198 [ 3670 ] {} test_15.r4 (b8428b65-4036-49d1-a93a-c7c1bd72c4c3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:31.011521 [ 3655 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {d7361de3-cb90-4044-830f-20b9d940375a::202510_1_16_3}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 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) @ 0x0000000039c89948 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000003999bfb7 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 @ 0x00000000399942f0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000039d15c04 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&) @ 0x0000000039d20399 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) @ 0x0000000039d1c606 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000396308a4 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x00000000396235dd 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000003963b3e0 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x00000000396504a0 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3c455d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:31.066408 [ 9433 ] {d048331c-1e35-46a6-a2ba-a309a2dd17d7} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=765, jobs=729). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44942) (comment: 00350_count_distinct.sql) (in query: SELECT count(DISTINCT x) FROM (SELECT number % 123 AS x FROM system.numbers LIMIT 1000);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:34:31.068750 [ 9433 ] {d048331c-1e35-46a6-a2ba-a309a2dd17d7} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=765, 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:34:31.083366 [ 3682 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:31.088611 [ 3654 ] {} 1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c::all_0_70_10 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:31.089446 [ 3654 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c::all_0_70_10}: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:31.164473 [ 3681 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:31.168638 [ 3646 ] {} 37341e51-1a17-4c44-9987-141583b579a2::all_0_70_10 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:31.168706 [ 3674 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:31.168909 [ 3672 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:31.169180 [ 3646 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {37341e51-1a17-4c44-9987-141583b579a2::all_0_70_10}: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:31.177177 [ 3680 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:31.179059 [ 3676 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:31.326734 [ 3652 ] {} 1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c::all_0_70_10 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:31.327240 [ 3652 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c::all_0_70_10}: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:31.353062 [ 3673 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:31.356030 [ 3656 ] {} b8428b65-4036-49d1-a93a-c7c1bd72c4c3::all_0_70_10 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:31.356550 [ 3656 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b8428b65-4036-49d1-a93a-c7c1bd72c4c3::all_0_70_10}: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:31.358116 [ 3677 ] {} test_15.r4 (b8428b65-4036-49d1-a93a-c7c1bd72c4c3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:31.359573 [ 3669 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:31.400783 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:34:31.402064 [ 9433 ] {a86fdf8a-5fc5-4790-bb8b-7b32b673a263} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44980) (comment: 02841_not_ready_set_bug.sh) (in query: CREATE TABLE t1 (`number` UInt64) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 36389, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 42, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 348015990, compact_parts_max_granules_to_buffer = 155, compact_parts_merge_max_bytes_to_prefetch_part = 24401878, merge_max_block_size = 15006, old_parts_lifetime = 359., prefer_fetch_merged_part_size_threshold = 344140317, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 4589132807, index_granularity_bytes = 20982878, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 18112, primary_key_compress_block_size = 48576), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x0000000039709f85 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>) @ 0x000000003a2e5f4a 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a2e404f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2d3063 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7b27a 12. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x0000000038308626 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348e414c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:34:31.404168 [ 9433 ] {a86fdf8a-5fc5-4790-bb8b-7b32b673a263} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x0000000039709f85 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>) @ 0x000000003a2e5f4a 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a2e404f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2d3063 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7b27a 12. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x0000000038308626 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348e414c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:34:31.691871 [ 3681 ] {} test_15.r5 (1b626045-cf30-44b2-91f1-3165d43b86e1): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:31.715364 [ 3649 ] {} 1b626045-cf30-44b2-91f1-3165d43b86e1::all_0_70_10 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:31.715927 [ 3649 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1b626045-cf30-44b2-91f1-3165d43b86e1::all_0_70_10}: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:31.796255 [ 3674 ] {} test_15.r5 (1b626045-cf30-44b2-91f1-3165d43b86e1): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:31.799108 [ 3678 ] {} test_15.r5 (1b626045-cf30-44b2-91f1-3165d43b86e1): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:31.803037 [ 3672 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:31.806310 [ 3656 ] {} 1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c::all_0_70_10 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:31.807289 [ 3656 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c::all_0_70_10}: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:31.818693 [ 3676 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:31.819042 [ 3667 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:31.881321 [ 3651 ] {} 37341e51-1a17-4c44-9987-141583b579a2::all_0_70_10 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:31.881852 [ 3651 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {37341e51-1a17-4c44-9987-141583b579a2::all_0_70_10}: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:31.885833 [ 3677 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:31.893256 [ 3682 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:32.104765 [ 3645 ] {} 1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c::all_0_70_10 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:32.105296 [ 3645 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c::all_0_70_10}: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:32.110021 [ 3681 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:32.115187 [ 3679 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:32.192599 [ 3675 ] {} test_15.r4 (b8428b65-4036-49d1-a93a-c7c1bd72c4c3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:32.192704 [ 3678 ] {} test_15.r4 (b8428b65-4036-49d1-a93a-c7c1bd72c4c3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:32.447670 [ 9453 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:34:32.486368 [ 3657 ] {} b8428b65-4036-49d1-a93a-c7c1bd72c4c3::all_0_70_10 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:32.486543 [ 3676 ] {} test_15.r4 (b8428b65-4036-49d1-a93a-c7c1bd72c4c3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:32.486904 [ 3657 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b8428b65-4036-49d1-a93a-c7c1bd72c4c3::all_0_70_10}: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:32.494805 [ 3670 ] {} test_15.r4 (b8428b65-4036-49d1-a93a-c7c1bd72c4c3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:32.494963 [ 3667 ] {} test_15.r4 (b8428b65-4036-49d1-a93a-c7c1bd72c4c3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:32.586961 [ 3682 ] {} test_15.r5 (1b626045-cf30-44b2-91f1-3165d43b86e1): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:32.671184 [ 3655 ] {} 1b626045-cf30-44b2-91f1-3165d43b86e1::all_0_70_10 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:32.671728 [ 3655 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1b626045-cf30-44b2-91f1-3165d43b86e1::all_0_70_10}: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:32.695269 [ 3674 ] {} test_15.r5 (1b626045-cf30-44b2-91f1-3165d43b86e1): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:32.695277 [ 3681 ] {} test_15.r5 (1b626045-cf30-44b2-91f1-3165d43b86e1): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:32.714856 [ 3672 ] {} test_15.r4 (b8428b65-4036-49d1-a93a-c7c1bd72c4c3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:32.716849 [ 3653 ] {} b8428b65-4036-49d1-a93a-c7c1bd72c4c3::all_0_70_10 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:32.717357 [ 3653 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b8428b65-4036-49d1-a93a-c7c1bd72c4c3::all_0_70_10}: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:32.726274 [ 3678 ] {} test_15.r4 (b8428b65-4036-49d1-a93a-c7c1bd72c4c3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:32.729747 [ 3680 ] {} test_15.r4 (b8428b65-4036-49d1-a93a-c7c1bd72c4c3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:32.766810 [ 3658 ] {} 1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c::all_0_70_10 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:32.767317 [ 3658 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c::all_0_70_10}: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:32.867864 [ 3677 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:32.868271 [ 3670 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:32.965873 [ 3649 ] {} 37341e51-1a17-4c44-9987-141583b579a2::all_0_70_10 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:32.966249 [ 3671 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:32.966451 [ 3649 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {37341e51-1a17-4c44-9987-141583b579a2::all_0_70_10}: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:33.007293 [ 3679 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:33.011802 [ 3674 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:33.140651 [ 9433 ] {011cb348-b55d-4ca3-b09a-fe0920159d18} executeQuery: Code: 60. DB::Exception: Table test_j5ansxgg.t1 does not exist. Maybe you meant test_1.t0?. (UNKNOWN_TABLE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:45008) (comment: 02841_not_ready_set_bug.sh) (in query: insert into t1 select number from numbers(10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x000000000861dc7f 4. ./build_docker/./src/Databases/IDatabase.cpp:39: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b146ec 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:433: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000003399fc33 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:957: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339b4ac1 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000034b9ec4f 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000034bb99c8 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:34:33.143909 [ 9433 ] {011cb348-b55d-4ca3-b09a-fe0920159d18} TCPHandler: Code: 60. DB::Exception: Table test_j5ansxgg.t1 does not exist. Maybe you meant test_1.t0?. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x000000000861dc7f 4. ./build_docker/./src/Databases/IDatabase.cpp:39: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b146ec 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:433: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000003399fc33 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:957: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339b4ac1 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000034b9ec4f 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000034bb99c8 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:34:33.282126 [ 10482 ] {da25eead-51cc-4e9c-96d9-3bb02464b34a} test_3.rmt (ReplicatedMergeTreePartCheckThread): ReplicatedCheckResult DB::ReplicatedMergeTreePartCheckThread::checkPartImpl(const String &, bool): Code: 107. DB::ErrnoException: Cannot open file /var/lib/clickhouse/store/1c5/1c58b3d3-3aa3-4fc2-81b4-6ea1ac046ae6/0_0_0_0/columns.txt: , errno: 2, strerror: No such file or directory. (FILE_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::ErrnoException::ErrnoException(int, int, FormatStringHelperImpl::type>, String const&) @ 0x000000002014960f 4. ./contrib/llvm-project/libcxx/include/optional:344: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String const&) @ 0x0000000020148d65 5. ./build_docker/./src/IO/OpenedFile.cpp:40: DB::OpenedFile::getFD() const @ 0x000000003072f0f6 6. ./src/IO/ReadBufferFromFile.h:0: DB::ReadBufferFromFilePReadWithDescriptorsCache::ReadBufferFromFilePReadWithDescriptorsCache(String const&, unsigned long, int, char*, unsigned long, std::optional, std::shared_ptr) @ 0x00000000307195c2 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::createReadBufferFromFileBase(String const&, DB::ReadSettings const&, std::optional, std::optional, int, char*, unsigned long)::$_0::operator()(unsigned long, unsigned long, int) const @ 0x0000000030717ea3 8. ./build_docker/./src/Disks/IO/createReadBufferFromFileBase.cpp:213: DB::createReadBufferFromFileBase(String const&, DB::ReadSettings const&, std::optional, std::optional, int, char*, unsigned long) @ 0x0000000030717ab1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::DiskLocal::readFile(String const&, DB::ReadSettings const&, std::optional, std::optional) const @ 0x0000000032eb853d 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::DataPartStorageOnDiskFull::readFile(String const&, DB::ReadSettings const&, std::optional, std::optional) const @ 0x00000000393c4195 11. ./build_docker/./src/Storages/MergeTree/checkDataPart.cpp:135: DB::checkDataPart(std::shared_ptr, DB::IDataPartStorage const&, DB::NamesAndTypesList const&, DB::MergeTreeDataPartType const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::ReadSettings const&, bool, std::function, bool&, bool) @ 0x000000003a2aec7d 12. ./build_docker/./src/Storages/MergeTree/checkDataPart.cpp:419: DB::checkDataPart(std::shared_ptr, bool, bool&, std::function, bool) @ 0x000000003a2ae12d 13. ./contrib/llvm-project/libcxx/include/__tree:1055: DB::ReplicatedMergeTreePartCheckThread::checkPartImpl(String const&, bool) @ 0x000000003a0aa8fc 14. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreePartCheckThread.cpp:445: DB::ReplicatedMergeTreePartCheckThread::checkPartAndFix(String const&, std::optional*, bool) @ 0x000000003a0b2a61 15. ./contrib/llvm-project/libcxx/include/string:2067: DB::StorageReplicatedMergeTree::checkDataNext(std::shared_ptr&) @ 0x0000000038a2ca8b 16. ./build_docker/./src/Interpreters/InterpreterCheckQuery.cpp:0: DB::(anonymous namespace)::TableCheckWorkerProcessor::transform(DB::Chunk&) @ 0x0000000035a22c6f 17. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acdc84 18. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae66ecb 19. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 25. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 27. ? @ 0x00007f100c857ac3 28. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:33.282863 [ 10482 ] {da25eead-51cc-4e9c-96d9-3bb02464b34a} test_3.rmt (ReplicatedMergeTreePartCheckThread): Part 0_0_0_0 looks broken. Removing it and will try to fetch. 2025.10.23 23:34:33.283228 [ 10482 ] {da25eead-51cc-4e9c-96d9-3bb02464b34a} test_3.rmt (ReplicatedMergeTreePartCheckThread): Part 0_0_0_0 exists in ZooKeeper and the local part was broken. Detaching it, removing from ZooKeeper and queueing a fetch. 2025.10.23 23:34:33.284323 [ 10482 ] {da25eead-51cc-4e9c-96d9-3bb02464b34a} test_3.rmt (1c58b3d3-3aa3-4fc2-81b4-6ea1ac046ae6): Detached 1 parts covered by broken part 0_0_0_0: 0_0_0_0 2025.10.23 23:34:33.295414 [ 10482 ] {da25eead-51cc-4e9c-96d9-3bb02464b34a} InterpreterCheckQuery: Check query for table test_3.rmt (1c58b3d3-3aa3-4fc2-81b4-6ea1ac046ae6) failed, path 0_0_0_0, reason: Part 0_0_0_0 looks broken. Removing it and will try to fetch. 2025.10.23 23:34:33.298825 [ 3894 ] {da25eead-51cc-4e9c-96d9-3bb02464b34a} 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.10542.altinitytest (altinity build)) (from [::1]:44972) (comment: 02253_empty_part_checksums.sh) (in query: check table rmt), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6377 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 2025.10.23 23:34:33.302424 [ 3894 ] {da25eead-51cc-4e9c-96d9-3bb02464b34a} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6377 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 2025.10.23 23:34:33.307766 [ 3091 ] {} test_3.rmt (1c58b3d3-3aa3-4fc2-81b4-6ea1ac046ae6): Directory /var/lib/clickhouse/store/1c5/1c58b3d3-3aa3-4fc2-81b4-6ea1ac046ae6/0_0_0_0 (part to remove) doesn't exist or one of nested files has gone. Most likely this is due to manual removing. This should be discouraged. Ignoring. 2025.10.23 23:34:33.376271 [ 3672 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:33.380529 [ 9558 ] {639099f2-b259-484e-9641-2d533e97ba43} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=6): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44888) (comment: 02184_nested_tuple.sql) (in query: SELECT * FROM t_nested_tuple 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000039d07892 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&) @ 0x0000000039d09d4a 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000032745572 12. ./build_docker/./src/DataTypes/Serializations/SerializationNamed.cpp:0: DB::SerializationNamed::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000003276d0e1 13. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:666: DB::SerializationTuple::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x00000000328624ea 14. ./build_docker/./src/DataTypes/Serializations/SerializationNamed.cpp:0: DB::SerializationNamed::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000003276d0e1 15. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:666: DB::SerializationTuple::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x00000000328624ea 16. ./build_docker/./src/DataTypes/Serializations/SerializationNamed.cpp:0: DB::SerializationNamed::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000003276d0e1 17. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:666: DB::SerializationTuple::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x00000000328624ea 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000032640cad 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000039d01224 20. ./contrib/llvm-project/libcxx/include/vector:547: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000039d00b49 21. ./contrib/llvm-project/libcxx/include/__tree:1088: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) @ 0x00000000399bb1c8 22. ./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 @ 0x00000000399b0254 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039d45fb0 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003bfd663a 25. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c083c53 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003bfe2b53 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d3c440 28. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf89b85 29. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 30. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 2025.10.23 23:34:33.382582 [ 9558 ] {639099f2-b259-484e-9641-2d533e97ba43} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=6): 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000039d07892 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&) @ 0x0000000039d09d4a 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000032745572 12. ./build_docker/./src/DataTypes/Serializations/SerializationNamed.cpp:0: DB::SerializationNamed::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000003276d0e1 13. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:666: DB::SerializationTuple::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x00000000328624ea 14. ./build_docker/./src/DataTypes/Serializations/SerializationNamed.cpp:0: DB::SerializationNamed::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000003276d0e1 15. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:666: DB::SerializationTuple::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x00000000328624ea 16. ./build_docker/./src/DataTypes/Serializations/SerializationNamed.cpp:0: DB::SerializationNamed::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000003276d0e1 17. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:666: DB::SerializationTuple::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x00000000328624ea 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000032640cad 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000039d01224 20. ./contrib/llvm-project/libcxx/include/vector:547: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000039d00b49 21. ./contrib/llvm-project/libcxx/include/__tree:1088: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) @ 0x00000000399bb1c8 22. ./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 @ 0x00000000399b0254 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039d45fb0 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003bfd663a 25. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c083c53 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003bfe2b53 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d3c440 28. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf89b85 29. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 30. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 2025.10.23 23:34:33.386864 [ 3646 ] {} 37341e51-1a17-4c44-9987-141583b579a2::all_0_70_10 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:33.387426 [ 3646 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {37341e51-1a17-4c44-9987-141583b579a2::all_0_70_10}: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:33.405141 [ 3673 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:33.411332 [ 3678 ] {} test_15.r3 (37341e51-1a17-4c44-9987-141583b579a2): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:33.504678 [ 9433 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:34:33.575237 [ 3644 ] {} 1b626045-cf30-44b2-91f1-3165d43b86e1::all_0_70_10 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:33.576552 [ 3644 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1b626045-cf30-44b2-91f1-3165d43b86e1::all_0_70_10}: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_0_70_10&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:170: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a027c23 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a0247c3 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a020eac 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:33.580890 [ 3667 ] {} test_15.r4 (b8428b65-4036-49d1-a93a-c7c1bd72c4c3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://2bb15604e207:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2F02725_start_stop_fetches_test_15%2Fr%2Freplicas%2Fr1&part=all_71_71_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.8.14.10542.altinitytest (altinity build)). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020979ea3 4. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x00000000209798e7 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb2a8c 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb4c38 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbda1 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb847c 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bb1b5a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020ba0786 14. ./src/IO/ReadWriteBufferFromHTTP.h:0: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003938897f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038aafc1d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003882f79c 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388072b0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000387c2a43 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aa8a90 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1817: DB::ReplicatedMergeTreeQueue::processEntry(std::function ()>, std::shared_ptr&, std::function&)>) @ 0x000000003a14092c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889f855 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038aaa639 23. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:33.716848 [ 4162 ] {} test_15.r1 (a9e12f64-7d79-4642-a352-4087db67ff97): Removing temporary directory /var/lib/clickhouse/store/a9e/a9e12f64-7d79-4642-a352-4087db67ff97/tmp-fetch_all_21_21_0/ 2025.10.23 23:34:33.982495 [ 3420 ] {} test_3.rmt (ReplicatedMergeTreePartCheckThread): No replica has part covering 0_0_0_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.10.23 23:34:34.026718 [ 9453 ] {0e11617d-a502-49f0-bc37-cb2ccb3a4b0c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=28, jobs=18). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:45098) (comment: 02253_empty_part_checksums.sh) (in query: select count() from rmt), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:34:34.086138 [ 9453 ] {0e11617d-a502-49f0-bc37-cb2ccb3a4b0c} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=28, jobs=18). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:34:34.126181 [ 3420 ] {} test_3.rmt (ReplicatedMergeTreePartCheckThread): Part 0_0_0_0 is lost forever. 2025.10.23 23:34:34.567392 [ 9433 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:34:34.743491 [ 3471 ] {} test_15.r2 (ReplicatedMergeTreePartCheckThread): void DB::ReplicatedMergeTreePartCheckThread::run(): Code: 999. Coordination::Exception: Coordination error: No node, path /clickhouse/tables/02725_start_stop_fetches_test_15/r/replicas/r1/parts. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x0000000030538e6c 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000003cbe740d 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreePartCheckThread.cpp:0: DB::ReplicatedMergeTreePartCheckThread::searchForMissingPartOnOtherReplicas(String const&) const @ 0x000000003a098808 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreePartCheckThread.cpp:493: DB::ReplicatedMergeTreePartCheckThread::checkPartAndFix(String const&, std::optional*, bool) @ 0x000000003a0b3641 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreePartCheckThread::run() @ 0x000000003a0ba7e1 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003a0bc7bf 9. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:34.799497 [ 3471 ] {} test_15.r2 (ReplicatedMergeTreePartCheckThread): No replica has part covering all_71_71_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.10.23 23:34:34.817674 [ 3471 ] {} test_15.r2 (ReplicatedMergeTreePartCheckThread): Part all_71_71_0 is lost forever. 2025.10.23 23:34:34.823794 [ 3471 ] {} test_15.r2 (ReplicatedMergeTreePartCheckThread): No replica has part covering all_68_68_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.10.23 23:34:35.031003 [ 3471 ] {} test_15.r2 (ReplicatedMergeTreePartCheckThread): Part all_68_68_0 is lost forever. 2025.10.23 23:34:35.486847 [ 9557 ] {a8704a3c-a0b2-4e12-aaee-7b2f65236923} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope WITH tab AS (SELECT min(number) FROM t1 PREWHERE number IN (SELECT number FROM view(SELECT number, row_number() OVER (PARTITION BY number % 2 ORDER BY number DESC) FROM numbers_mt(10000.)) WHERE number != 2 ORDER BY number ASC)) SELECT number FROM t1. (UNKNOWN_TABLE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:45090) (comment: 02841_not_ready_set_bug.sh) (in query: with tab as (select min(number) from t1 prewhere number in (select number from view(select number, row_number() OVER (partition by number % 2 ORDER BY number DESC) from numbers_mt(1e4)) where number != 2 order by number)) select number from t1 union all select * from tab;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa0996d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334eae8a 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003343676d 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5715: DB::QueryAnalyzer::resolveUnion(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033441553 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:148: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334a6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:34:35.489401 [ 9557 ] {a8704a3c-a0b2-4e12-aaee-7b2f65236923} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope WITH tab AS (SELECT min(number) FROM t1 PREWHERE number IN (SELECT number FROM view(SELECT number, row_number() OVER (PARTITION BY number % 2 ORDER BY number DESC) FROM numbers_mt(10000.)) WHERE number != 2 ORDER BY number ASC)) SELECT number FROM t1. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa0996d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334eae8a 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003343676d 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5715: DB::QueryAnalyzer::resolveUnion(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033441553 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:148: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334a6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:34:35.668655 [ 9453 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:34:35.670067 [ 9433 ] {d166d614-1c84-4e3a-8af4-f151230a8e08} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=765, jobs=729). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:47680) (comment: 01293_client_interactive_vertical_singleline.expect) (in query: SELECT 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:34:35.672581 [ 9433 ] {d166d614-1c84-4e3a-8af4-f151230a8e08} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=765, 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:34:35.816436 [ 9434 ] {79c2926d-5ea4-40d5-a934-cfb42ea86d38} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:45110) (comment: 03215_analyzer_replace_with_dummy_tables.sql) (in query: CREATE TABLE t (`number` UInt64) ENGINE = MergeTree ORDER BY number SETTINGS index_granularity = 30763, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.5221977233886719, 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 = 167803713, compact_parts_max_granules_to_buffer = 193, compact_parts_merge_max_bytes_to_prefetch_part = 31405422, merge_max_block_size = 6850, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 5951493098, index_granularity_bytes = 30856833, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 84147, primary_key_compress_block_size = 25041), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x0000000039709f85 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>) @ 0x000000003a2e5f4a 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a2e404f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2d3063 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7b27a 12. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x0000000038308626 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348e414c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:34:35.817579 [ 9434 ] {79c2926d-5ea4-40d5-a934-cfb42ea86d38} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x0000000039709f85 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>) @ 0x000000003a2e5f4a 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a2e404f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2d3063 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7b27a 12. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x0000000038308626 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348e414c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:34:36.746666 [ 9453 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:34:36.952128 [ 3130 ] {} test_3.rmt (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.10.23 23:34:36.952206 [ 3135 ] {} test_15.r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.10.23 23:34:37.727333 [ 4672 ] {d51544e7-3230-4f4c-9c70-d607c6c16e7e} executeQuery: Code: 36. DB::Exception: The absolute data path should be inside `user_files_path`(/var/lib/clickhouse/user_files/). (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:47738) (comment: 02125_fix_storage_filelog.sql) (in query: CREATE TABLE log (A String) ENGINE= FileLog('/tmp/aaa.csv', 'CSV');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Storages/FileLog/StorageFileLog.cpp:161: DB::StorageFileLog::StorageFileLog(DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String const&, String const&, String const&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel) @ 0x0000000038e0b1ca 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel const&, void>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>&&, String const&, DB::LoadingStrictnessLevel const&) @ 0x0000000038e4de2a 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000038e34d6b 7. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x0000000038308626 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348e414c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:34:37.728579 [ 4672 ] {d51544e7-3230-4f4c-9c70-d607c6c16e7e} TCPHandler: Code: 36. DB::Exception: The absolute data path should be inside `user_files_path`(/var/lib/clickhouse/user_files/). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Storages/FileLog/StorageFileLog.cpp:161: DB::StorageFileLog::StorageFileLog(DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String const&, String const&, String const&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel) @ 0x0000000038e0b1ca 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel const&, void>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>&&, String const&, DB::LoadingStrictnessLevel const&) @ 0x0000000038e4de2a 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000038e34d6b 7. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x0000000038308626 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348e414c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:34:37.738897 [ 4672 ] {2f9c4fa7-1ece-4e98-8167-df00c9966c46} executeQuery: Code: 36. DB::Exception: The absolute data path should be inside `user_files_path`(/var/lib/clickhouse/user_files/). (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:47738) (comment: 02125_fix_storage_filelog.sql) (in query: CREATE TABLE log (A String) ENGINE= FileLog('/tmp/aaa.csv', 'CSV');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Storages/FileLog/StorageFileLog.cpp:161: DB::StorageFileLog::StorageFileLog(DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String const&, String const&, String const&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel) @ 0x0000000038e0b1ca 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel const&, void>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>&&, String const&, DB::LoadingStrictnessLevel const&) @ 0x0000000038e4de2a 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000038e34d6b 7. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x0000000038308626 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348e414c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:34:37.739768 [ 4672 ] {2f9c4fa7-1ece-4e98-8167-df00c9966c46} TCPHandler: Code: 36. DB::Exception: The absolute data path should be inside `user_files_path`(/var/lib/clickhouse/user_files/). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Storages/FileLog/StorageFileLog.cpp:161: DB::StorageFileLog::StorageFileLog(DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String const&, String const&, String const&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel) @ 0x0000000038e0b1ca 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel const&, void>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>&&, String const&, DB::LoadingStrictnessLevel const&) @ 0x0000000038e4de2a 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000038e34d6b 7. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x0000000038308626 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348e414c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:34:37.754347 [ 4672 ] {832a7029-dad1-4344-a80b-e7a9bd09ab30} executeQuery: Code: 36. DB::Exception: The absolute data path should be inside `user_files_path`(/var/lib/clickhouse/user_files/). (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:47738) (comment: 02125_fix_storage_filelog.sql) (in query: CREATE TABLE log (A String) ENGINE= FileLog('/tmp/aaa.csv', 'CSV');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Storages/FileLog/StorageFileLog.cpp:161: DB::StorageFileLog::StorageFileLog(DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String const&, String const&, String const&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel) @ 0x0000000038e0b1ca 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel const&, void>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>&&, String const&, DB::LoadingStrictnessLevel const&) @ 0x0000000038e4de2a 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000038e34d6b 7. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x0000000038308626 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348e414c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:34:37.755270 [ 4672 ] {832a7029-dad1-4344-a80b-e7a9bd09ab30} TCPHandler: Code: 36. DB::Exception: The absolute data path should be inside `user_files_path`(/var/lib/clickhouse/user_files/). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Storages/FileLog/StorageFileLog.cpp:161: DB::StorageFileLog::StorageFileLog(DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String const&, String const&, String const&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel) @ 0x0000000038e0b1ca 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel const&, void>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>&&, String const&, DB::LoadingStrictnessLevel const&) @ 0x0000000038e4de2a 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000038e34d6b 7. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x0000000038308626 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348e414c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:34:37.794689 [ 9453 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:34:38.258267 [ 3687 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 999. Coordination::Exception: Coordination error: Session expired, path /clickhouse/tables/02725_start_stop_fetches_test_15/r/replicas/r2/parts/all_71_71_0. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x0000000030538e6c 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1248: void std::__function::__policy_invoker::__call_impl)::$_0, void (Coordination::ExistsResponse const&)>>(std::__function::__policy_storage const*, Coordination::ExistsResponse const&) @ 0x000000003cc2d887 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003cd2a730 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003ccf9127 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003cd16e77 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003cd2369f 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe6e6d 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe5f26 11. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe84e7 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000003cbe7761 13. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x000000003a061e9e 14. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x000000003a04fe19 15. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:165: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a04156e 16. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:50: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a03dd98 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003a06697f 18. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 20. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 21. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:38.438578 [ 3655 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {8c494fec-2d59-4135-a0d6-29ba8d5d4dac::202510_1_21_3}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 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) @ 0x0000000039c89948 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000003999bfb7 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 @ 0x00000000399942f0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000039d15c04 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&) @ 0x0000000039d20399 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) @ 0x0000000039d1c606 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000396308a4 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x00000000396235dd 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000003963b3e0 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x00000000396504a0 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3c455d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:38.454831 [ 3171 ] {} test_3.rmt (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Session expired (fault injected on send). (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000003a21d8b1 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEES0_NS_5ErrorEOS5_ @ 0x000000003cd2cd64 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1654: Coordination::ZooKeeper::maybeInjectSendFault() @ 0x000000003cd17122 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003cd165e8 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003cd2369f 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe6e6d 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe5f26 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe84e7 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000003cbe7761 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x000000003a061e9e 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x000000003a04fe19 13. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:165: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a04156e 14. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:50: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a03dd98 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003a06697f 16. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 18. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 21. ? @ 0x00007f100c857ac3 22. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:38.530942 [ 3155 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000003cc8de51 3. ./src/Common/ZooKeeper/IKeeper.h:509: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003cd16a3e 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1383: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x000000003cd1a472 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x000000003cbf5306 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:610: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x000000003cbf42db 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000003cbf676b 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003cbf5ab3 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x000000003a0eb80c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889e7df 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:38.530971 [ 3136 ] {} test_3.rmt (1c58b3d3-3aa3-4fc2-81b4-6ea1ac046ae6): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000003cc8de51 3. ./src/Common/ZooKeeper/IKeeper.h:509: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003cd16a3e 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1383: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x000000003cd1a472 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x000000003cbf5306 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:610: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x000000003cbf42db 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000003cbf676b 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003cbf5ab3 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x000000003a0eb80c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889e7df 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:38.554569 [ 3158 ] {} test_3.rmt (1c58b3d3-3aa3-4fc2-81b4-6ea1ac046ae6): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000003cc8de51 3. ./src/Common/ZooKeeper/IKeeper.h:509: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003cd16a3e 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003cd2369f 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe6e6d 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe5f26 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe84e7 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe81ea 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000003a10064e 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000003889f11d 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f9f 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:38.554605 [ 3143 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000003cc8de51 3. ./src/Common/ZooKeeper/IKeeper.h:509: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003cd16a3e 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003cd2369f 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe6e6d 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe5f26 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe84e7 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe81ea 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000003a10064e 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000003889f11d 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f9f 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:38.837311 [ 6969 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:34:39.851922 [ 4672 ] {c4fe2bdb-d6cc-408b-bcb7-63f7d2ca5ae1} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:47876) (comment: 02479_analyzer_aggregation_crash.sql) (in query: CREATE TABLE lc_00906__fuzz_46 (`b` Int64) ENGINE = MergeTree ORDER BY b SETTINGS index_granularity = 17117, min_bytes_for_wide_part = 982679643, 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 = 500064210, compact_parts_max_granules_to_buffer = 44, compact_parts_merge_max_bytes_to_prefetch_part = 2130368, merge_max_block_size = 8851, old_parts_lifetime = 379., prefer_fetch_merged_part_size_threshold = 1908630402, vertical_merge_algorithm_min_rows_to_activate = 126444, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 1699772930, index_granularity_bytes = 18507944, concurrent_part_removal_threshold = 31, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 30581, primary_key_compress_block_size = 92512), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x0000000039709f85 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>) @ 0x000000003a2e5f4a 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a2e404f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2d3063 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7b27a 12. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x0000000038308626 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348e414c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:34:39.854620 [ 4672 ] {c4fe2bdb-d6cc-408b-bcb7-63f7d2ca5ae1} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x0000000039709f85 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>) @ 0x000000003a2e5f4a 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a2e404f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2d3063 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7b27a 12. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x0000000038308626 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348e414c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:34:39.886806 [ 10275 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:34:40.053566 [ 3655 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {d60c8165-1f8c-4cd1-8084-8b8c63363ea3::202510_1_36_7}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 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) @ 0x0000000039c89948 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000003999bfb7 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 @ 0x00000000399942f0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000039d15c04 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&) @ 0x0000000039d20399 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) @ 0x0000000039d1c606 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000396308a4 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x00000000396235dd 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000003963b3e0 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x00000000396504a0 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3c455d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:40.522096 [ 9678 ] {375553a5-4c97-43e3-8e3a-d4e525229aaf} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, jobs=14). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:47862) (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6377 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 2025.10.23 23:34:40.635121 [ 9678 ] {375553a5-4c97-43e3-8e3a-d4e525229aaf} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6377 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 2025.10.23 23:34:40.957880 [ 9434 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:34:42.070104 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:34:42.703371 [ 4672 ] {7ec2e471-42b2-4ec4-ab60-6d787145efb5} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44616) (comment: 01881_create_as_tuple.sql) (in query: DROP DATABASE IF EXISTS test_ib55jsax ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:34:42.706398 [ 4672 ] {7ec2e471-42b2-4ec4-ab60-6d787145efb5} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:43.062239 [ 7652 ] {6eb90bd4-bbfe-4984-bfe2-542a1116734b} executeQuery: Code: 36. DB::Exception: The absolute data path should be inside `user_files_path`(/var/lib/clickhouse/user_files/). (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:47990) (comment: 02126_fix_filelog.sh) (in query: create table file_log(k UInt8, v UInt8) engine=FileLog('/tmp/aaa.csv', 'CSV');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Storages/FileLog/StorageFileLog.cpp:161: DB::StorageFileLog::StorageFileLog(DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String const&, String const&, String const&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel) @ 0x0000000038e0b1ca 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel const&, void>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>&&, String const&, DB::LoadingStrictnessLevel const&) @ 0x0000000038e4de2a 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000038e34d6b 7. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x0000000038308626 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348e414c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:34:43.064206 [ 7652 ] {6eb90bd4-bbfe-4984-bfe2-542a1116734b} TCPHandler: Code: 36. DB::Exception: The absolute data path should be inside `user_files_path`(/var/lib/clickhouse/user_files/). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Storages/FileLog/StorageFileLog.cpp:161: DB::StorageFileLog::StorageFileLog(DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String const&, String const&, String const&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel) @ 0x0000000038e0b1ca 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel const&, void>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>&&, String const&, DB::LoadingStrictnessLevel const&) @ 0x0000000038e4de2a 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000038e34d6b 7. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x0000000038308626 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348e414c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:34:43.134139 [ 9434 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:34:43.290047 [ 6969 ] {d3e369c8-6df5-4b89-82b4-e47568a45268} executeQuery: Code: 57. DB::Exception: Table test_3.subcolumns already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:47964) (comment: 01475_read_subcolumns_2.sql) (in query: CREATE TABLE subcolumns (`t` Tuple(a Array(Nullable(UInt32)), u UInt32, s Nullable(String)), `arr` Array(Nullable(String)), `arr2` Array(Array(Nullable(String))), `lc` LowCardinality(String), `nested` Nested(col1 String, col2 Nullable(UInt32))) ENGINE = MergeTree ORDER BY tuple() SETTINGS min_bytes_for_wide_part = 0, index_granularity = 55338, 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 = 269790635, compact_parts_max_bytes_to_buffer = 44478088, compact_parts_max_granules_to_buffer = 112, compact_parts_merge_max_bytes_to_prefetch_part = 29381483, merge_max_block_size = 22644, 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 = 87, min_merge_bytes_to_use_direct_io = 8271918878, index_granularity_bytes = 1637532, concurrent_part_removal_threshold = 68, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 79873, primary_key_compress_block_size = 63894), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:34:43.292192 [ 6969 ] {d3e369c8-6df5-4b89-82b4-e47568a45268} TCPHandler: Code: 57. DB::Exception: Table test_3.subcolumns already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:34:43.486890 [ 3658 ] {94974921-abe0-449e-b175-9011094d9f5b::all_1_1_0_2} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, jobs=14). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:43.487374 [ 3658 ] {94974921-abe0-449e-b175-9011094d9f5b::all_1_1_0_2} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, jobs=14). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6377 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:43.756706 [ 7652 ] {998591e9-c657-4a92-8fe1-2240f3f439cb} executeQuery: Code: 36. DB::Exception: The absolute data path should be inside `user_files_path`(/var/lib/clickhouse/user_files/). (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48016) (comment: 02126_fix_filelog.sh) (in query: create table file_log(k UInt8, v UInt8) engine=FileLog('/tmp/aaa.csv', 'CSV');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Storages/FileLog/StorageFileLog.cpp:161: DB::StorageFileLog::StorageFileLog(DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String const&, String const&, String const&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel) @ 0x0000000038e0b1ca 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel const&, void>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>&&, String const&, DB::LoadingStrictnessLevel const&) @ 0x0000000038e4de2a 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000038e34d6b 7. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x0000000038308626 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348e414c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:34:43.758569 [ 7652 ] {998591e9-c657-4a92-8fe1-2240f3f439cb} TCPHandler: Code: 36. DB::Exception: The absolute data path should be inside `user_files_path`(/var/lib/clickhouse/user_files/). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Storages/FileLog/StorageFileLog.cpp:161: DB::StorageFileLog::StorageFileLog(DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String const&, String const&, String const&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel) @ 0x0000000038e0b1ca 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel const&, void>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>&&, String const&, DB::LoadingStrictnessLevel const&) @ 0x0000000038e4de2a 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000038e34d6b 7. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x0000000038308626 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348e414c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:34:44.147550 [ 3645 ] {94974921-abe0-449e-b175-9011094d9f5b::all_1_1_0_2} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, jobs=14). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:44.148141 [ 3645 ] {94974921-abe0-449e-b175-9011094d9f5b::all_1_1_0_2} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, jobs=14). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6377 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:44.223482 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:34:44.499487 [ 4675 ] {74d89955-c12b-4cba-9c08-c41eead24a24} executeQuery: Code: 36. DB::Exception: The absolute data path should be inside `user_files_path`(/var/lib/clickhouse/user_files/). (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48042) (comment: 02126_fix_filelog.sh) (in query: create table file_log(k UInt8, v UInt8) engine=FileLog('/tmp/aaa.csv', 'CSV');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Storages/FileLog/StorageFileLog.cpp:161: DB::StorageFileLog::StorageFileLog(DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String const&, String const&, String const&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel) @ 0x0000000038e0b1ca 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel const&, void>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>&&, String const&, DB::LoadingStrictnessLevel const&) @ 0x0000000038e4de2a 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000038e34d6b 7. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x0000000038308626 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348e414c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:34:44.502327 [ 4675 ] {74d89955-c12b-4cba-9c08-c41eead24a24} TCPHandler: Code: 36. DB::Exception: The absolute data path should be inside `user_files_path`(/var/lib/clickhouse/user_files/). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Storages/FileLog/StorageFileLog.cpp:161: DB::StorageFileLog::StorageFileLog(DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String const&, String const&, String const&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel) @ 0x0000000038e0b1ca 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel const&, void>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>&&, String const&, DB::LoadingStrictnessLevel const&) @ 0x0000000038e4de2a 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000038e34d6b 7. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x0000000038308626 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348e414c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:34:44.510522 [ 3657 ] {94974921-abe0-449e-b175-9011094d9f5b::all_1_1_0_2} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=5). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:44.511180 [ 3657 ] {94974921-abe0-449e-b175-9011094d9f5b::all_1_1_0_2} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=5). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:44.600637 [ 4672 ] {0cb4109f-7b9f-45ef-ad42-c58dba14a562} 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=14, jobs=14). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.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.10542.altinitytest (altinity build)) (from [::1]:47980) (comment: 01550_mutation_subquery.sql) (in query: ALTER TABLE t DELETE WHERE id in (select id from t as tmp);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&) @ 0x0000000039c1c97f 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000039c1c6e5 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003a2fe259 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003a3016f5 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034866f33 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003485e550 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:34:44.602281 [ 4672 ] {0cb4109f-7b9f-45ef-ad42-c58dba14a562} 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=14, jobs=14). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&) @ 0x0000000039c1c97f 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000039c1c6e5 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003a2fe259 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003a3016f5 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034866f33 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003485e550 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:34:44.922072 [ 6969 ] {df0e261d-fe79-429a-b35e-06d88a754a04} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:35550) (comment: 00981_no_virtual_columns.sql) (in query: DROP DATABASE IF EXISTS test_wtjsv9ky ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:34:44.923807 [ 6969 ] {df0e261d-fe79-429a-b35e-06d88a754a04} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:45.008030 [ 7652 ] {9cc7418a-bcdc-4a7d-8eb7-892fb3e5dd40} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:35560) (comment: 00981_no_virtual_columns.sql) (in query: DROP DATABASE IF EXISTS test_wtjsv9ky ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:34:45.010016 [ 7652 ] {9cc7418a-bcdc-4a7d-8eb7-892fb3e5dd40} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:45.335629 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:34:45.645890 [ 7760 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:34:45.713793 [ 10275 ] {46058004-aa1d-4230-828f-16cdd6738a74} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage FileLog. (NOT_IMPLEMENTED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44388) (comment: 02126_fix_filelog.sh) (in query: drop table file_log;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000002ffc5e67 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003493f2d5 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:34:45.715604 [ 10275 ] {46058004-aa1d-4230-828f-16cdd6738a74} TCPHandler: Code: 48. DB::Exception: Truncate is not supported by storage FileLog. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000002ffc5e67 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003493f2d5 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:34:46.200327 [ 9678 ] {b7c47ca8-b348-4ae6-b113-756090d6babe} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=765, jobs=731). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:59028) (comment: 03205_parallel_replicas_alter_select_ubsan.sql) (in query: SELECT toIntervalMonth(1), 2 FROM `test_txrubaor`.`t1__fuzz_26` GROUP BY toNullable(12) 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:34:46.201569 [ 9678 ] {b7c47ca8-b348-4ae6-b113-756090d6babe} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=765, jobs=731). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:34:46.219917 [ 7652 ] {69a71cc8-4e88-4c00-918b-a385ff4b4341} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Cannot schedule a task: fault injected (threads=765, jobs=731). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 : While executing Remote: While processing (SELECT toIntervalMonth(1), 2 FROM test_txrubaor.t1__fuzz_26 GROUP BY toFixedString('%Prewhere%', 10), toNullable(12) WITH ROLLUP) AS _subquery7: While processing viewExplain('EXPLAIN', 'actions = 1', (SELECT toIntervalMonth(1), 2 FROM test_txrubaor.t1__fuzz_26 GROUP BY toFixedString('%Prewhere%', 10), toNullable(12) WITH ROLLUP) AS _subquery7): While processing toIntervalMonth(viewExplain('EXPLAIN', 'actions = 1', (SELECT toIntervalMonth(1), 2 FROM test_txrubaor.t1__fuzz_26 GROUP BY toFixedString('%Prewhere%', 10), toNullable(12) WITH ROLLUP) AS _subquery7), 1): While processing toDateTime(b) + toIntervalMonth(viewExplain('EXPLAIN', 'actions = 1', (SELECT toIntervalMonth(1), 2 FROM test_txrubaor.t1__fuzz_26 GROUP BY toFixedString('%Prewhere%', 10), toNullable(12) WITH ROLLUP) AS _subquery7), 1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44358) (comment: 03205_parallel_replicas_alter_select_ubsan.sql) (in query: ALTER TABLE t1 (MODIFY COLUMN `a` Float64 TTL toDateTime(b) + toIntervalMonth(viewExplain('EXPLAIN', 'actions = 1', ( SELECT toIntervalMonth(1), 2 FROM t1__fuzz_26 GROUP BY toFixedString('%Prewhere%', 10), toNullable(12) WITH ROLLUP )), 1)) settings allow_experimental_parallel_reading_from_replicas = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002019af32 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000003a7e3e0c 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::Connection::receivePacket() @ 0x000000003a7ff61b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:340: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003a8df9b9 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:0: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000032358b71 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000323566d1 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032355a26 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000032352f12 2025.10.23 23:34:46.221948 [ 7652 ] {69a71cc8-4e88-4c00-918b-a385ff4b4341} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Cannot schedule a task: fault injected (threads=765, jobs=731). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 : While executing Remote: While processing (SELECT toIntervalMonth(1), 2 FROM test_txrubaor.t1__fuzz_26 GROUP BY toFixedString('%Prewhere%', 10), toNullable(12) WITH ROLLUP) AS _subquery7: While processing viewExplain('EXPLAIN', 'actions = 1', (SELECT toIntervalMonth(1), 2 FROM test_txrubaor.t1__fuzz_26 GROUP BY toFixedString('%Prewhere%', 10), toNullable(12) WITH ROLLUP) AS _subquery7): While processing toIntervalMonth(viewExplain('EXPLAIN', 'actions = 1', (SELECT toIntervalMonth(1), 2 FROM test_txrubaor.t1__fuzz_26 GROUP BY toFixedString('%Prewhere%', 10), toNullable(12) WITH ROLLUP) AS _subquery7), 1): While processing toDateTime(b) + toIntervalMonth(viewExplain('EXPLAIN', 'actions = 1', (SELECT toIntervalMonth(1), 2 FROM test_txrubaor.t1__fuzz_26 GROUP BY toFixedString('%Prewhere%', 10), toNullable(12) WITH ROLLUP) AS _subquery7), 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002019af32 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000003a7e3e0c 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::Connection::receivePacket() @ 0x000000003a7ff61b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:340: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003a8df9b9 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:0: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000032358b71 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000323566d1 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032355a26 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000032352f12 2025.10.23 23:34:46.340065 [ 4675 ] {2f8f9eb9-e97f-4335-941b-4b613c4264e4} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:35608) (comment: 03205_parallel_replicas_alter_select_ubsan.sql) (in query: DROP DATABASE IF EXISTS test_txrubaor ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:34:46.341744 [ 4675 ] {2f8f9eb9-e97f-4335-941b-4b613c4264e4} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:46.375437 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:34:47.461258 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:34:47.537426 [ 9558 ] {fa0126a7-f0b8-48dc-b8f2-dab090ee2863} executeQuery: Code: 60. DB::Exception: Table test_11.t_json_6 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44392) (comment: 01825_type_json_6.sh) (in query: INSERT INTO t_json_6 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b14381 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:433: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000003399fc33 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:957: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339b4ac1 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000034b9ec4f 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000034bb99c8 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:34:47.539202 [ 9558 ] {fa0126a7-f0b8-48dc-b8f2-dab090ee2863} TCPHandler: Code: 60. DB::Exception: Table test_11.t_json_6 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b14381 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:433: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000003399fc33 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:957: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339b4ac1 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000034b9ec4f 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000034bb99c8 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:34:47.748135 [ 9434 ] {b0ea8da5-afc6-46d2-bbb9-bfd691a3ec32} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44336) (comment: 02540_date_column_consistent_insert_behaviour.sql) (in query: SELECT x, txt FROM 02540_date WHERE txt == 'CAST(65535 as UInt32)';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:34:47.750835 [ 9434 ] {b0ea8da5-afc6-46d2-bbb9-bfd691a3ec32} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:34:48.511219 [ 9434 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:34:49.002301 [ 3894 ] {76d0de73-fbce-47d7-b7d3-6c363e90bbe9} executeQuery: Code: 691. DB::Exception: Unknown element '' for enum: In scope SELECT CAST(CAST('', 'Nullable(String)'), 'Nullable(Enum8(\'Hello\' = 1))'). (UNKNOWN_ELEMENT_OF_ENUM) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44402) (comment: 01402_cast_nullable_string_to_enum.sql) (in query: -- empty string still not acceptable SELECT CAST(CAST('' AS Nullable(String)) AS Nullable(Enum8('Hello' = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000df2a32d 4. ./build_docker/./src/DataTypes/EnumValues.cpp:72: DB::EnumValues<_BitInt(8)>::getValue(StringRef, bool) const @ 0x000000003253294c 5. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createStringToEnumWrapper>() 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) @ 0x0000000008f2fe6b 6. 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::'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) @ 0x00000000091c354e 7. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086d2b34 8. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008425b22 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601e5f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 2025.10.23 23:34:49.004265 [ 3894 ] {76d0de73-fbce-47d7-b7d3-6c363e90bbe9} TCPHandler: Code: 691. DB::Exception: Unknown element '' for enum: In scope SELECT CAST(CAST('', 'Nullable(String)'), 'Nullable(Enum8(\'Hello\' = 1))'). (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000df2a32d 4. ./build_docker/./src/DataTypes/EnumValues.cpp:72: DB::EnumValues<_BitInt(8)>::getValue(StringRef, bool) const @ 0x000000003253294c 5. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createStringToEnumWrapper>() 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) @ 0x0000000008f2fe6b 6. 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::'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) @ 0x00000000091c354e 7. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086d2b34 8. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008425b22 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601e5f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 2025.10.23 23:34:49.500532 [ 7652 ] {2a7aa34f-9aac-42dd-9106-706ff583e497} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't_json_6' in scope SELECT DISTINCT toTypeName(data) FROM t_json_6. (UNKNOWN_TABLE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44416) (comment: 01825_type_json_6.sh) (in query: SELECT DISTINCT toTypeName(data) FROM t_json_6;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa0996d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334eae8a 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003343676d 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 2025.10.23 23:34:49.502197 [ 7652 ] {2a7aa34f-9aac-42dd-9106-706ff583e497} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't_json_6' in scope SELECT DISTINCT toTypeName(data) FROM t_json_6. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa0996d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334eae8a 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003343676d 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 2025.10.23 23:34:49.557840 [ 9434 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:34:50.243298 [ 7652 ] {6434f3dc-b5a8-4b68-b08e-b04da5ee5659} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't_json_6' in scope SELECT data.key, data.out.type, data.out.value, data.out.outputs.index, data.out.outputs.n FROM t_json_6 ORDER BY data.key ASC. (UNKNOWN_TABLE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44444) (comment: 01825_type_json_6.sh) (in query: SELECT data.key, data.out.type, data.out.value, data.out.outputs.index, data.out.outputs.n FROM t_json_6 ORDER BY data.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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa0996d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334eae8a 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003343676d 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 2025.10.23 23:34:50.245193 [ 7652 ] {6434f3dc-b5a8-4b68-b08e-b04da5ee5659} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't_json_6' in scope SELECT data.key, data.out.type, data.out.value, data.out.outputs.index, data.out.outputs.n FROM t_json_6 ORDER BY data.key 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa0996d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334eae8a 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003343676d 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 2025.10.23 23:34:50.610838 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:34:50.968610 [ 3894 ] {9ef5e6b4-306f-4265-89f7-d8cb677bf25b} executeQuery: Code: 691. DB::Exception: Unknown element '' for enum: In scope SELECT CAST(CAST('', 'Nullable(FixedString(1))'), 'Nullable(Enum8(\'Hello\' = 1))'). (UNKNOWN_ELEMENT_OF_ENUM) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44402) (comment: 01402_cast_nullable_string_to_enum.sql) (in query: SELECT CAST(CAST('' AS Nullable(FixedString(1))) AS Nullable(Enum8('Hello' = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000df2a32d 4. ./build_docker/./src/DataTypes/EnumValues.cpp:72: DB::EnumValues<_BitInt(8)>::getValue(StringRef, bool) const @ 0x000000003253294c 5. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createStringToEnumWrapper>() 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) @ 0x0000000008f30de3 6. 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::'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) @ 0x00000000091c354e 7. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086d2b34 8. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008425b22 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601e5f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 2025.10.23 23:34:50.969783 [ 3894 ] {9ef5e6b4-306f-4265-89f7-d8cb677bf25b} TCPHandler: Code: 691. DB::Exception: Unknown element '' for enum: In scope SELECT CAST(CAST('', 'Nullable(FixedString(1))'), 'Nullable(Enum8(\'Hello\' = 1))'). (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000df2a32d 4. ./build_docker/./src/DataTypes/EnumValues.cpp:72: DB::EnumValues<_BitInt(8)>::getValue(StringRef, bool) const @ 0x000000003253294c 5. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createStringToEnumWrapper>() 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) @ 0x0000000008f30de3 6. 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::'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) @ 0x00000000091c354e 7. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086d2b34 8. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008425b22 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601e5f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 2025.10.23 23:34:51.773406 [ 9434 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:34:52.529272 [ 7652 ] {10d716b8-e633-4d30-8fde-91ba62cbfed1} executeQuery: Code: 60. DB::Exception: Table test_11.t_json_6 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44474) (comment: 01825_type_json_6.sh) (in query: DROP TABLE t_json_6;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b14381 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:433: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000003399fc33 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339b5107 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003493bddb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:34:52.531611 [ 7652 ] {10d716b8-e633-4d30-8fde-91ba62cbfed1} TCPHandler: Code: 60. DB::Exception: Table test_11.t_json_6 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b14381 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:433: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000003399fc33 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339b5107 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003493bddb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:34:52.880240 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:34:53.402028 [ 3894 ] {56df5eea-f58c-42d9-8e82-410f326940a7} executeQuery: Code: 349. DB::Exception: Cannot convert NULL value to non-Nullable type: In scope SELECT CAST(CAST(NULL, 'Nullable(String)'), 'Enum8(\'Hello\' = 1)'). (CANNOT_INSERT_NULL_IN_ORDINARY_COLUMN) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44402) (comment: 01402_cast_nullable_string_to_enum.sql) (in query: -- non-Nullable Enum() still not acceptable SELECT CAST(CAST(NULL AS Nullable(String)) AS Enum8('Hello' = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 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) @ 0x00000000091c4b52 5. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086d2b34 6. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008425b22 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601e5f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 2025.10.23 23:34:53.403190 [ 3894 ] {56df5eea-f58c-42d9-8e82-410f326940a7} TCPHandler: Code: 349. DB::Exception: Cannot convert NULL value to non-Nullable type: In scope SELECT CAST(CAST(NULL, 'Nullable(String)'), 'Enum8(\'Hello\' = 1)'). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 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) @ 0x00000000091c4b52 5. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086d2b34 6. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008425b22 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601e5f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 2025.10.23 23:34:53.420067 [ 3894 ] {28ad5bd1-38d9-4daa-8a06-a746754bbb55} executeQuery: Code: 349. DB::Exception: Cannot convert NULL value to non-Nullable type: In scope SELECT CAST(CAST(NULL, 'Nullable(FixedString(1))'), 'Enum8(\'Hello\' = 1)'). (CANNOT_INSERT_NULL_IN_ORDINARY_COLUMN) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44402) (comment: 01402_cast_nullable_string_to_enum.sql) (in query: SELECT CAST(CAST(NULL AS Nullable(FixedString(1))) AS Enum8('Hello' = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 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) @ 0x00000000091c4b52 5. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086d2b34 6. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008425b22 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601e5f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 2025.10.23 23:34:53.421320 [ 3894 ] {28ad5bd1-38d9-4daa-8a06-a746754bbb55} TCPHandler: Code: 349. DB::Exception: Cannot convert NULL value to non-Nullable type: In scope SELECT CAST(CAST(NULL, 'Nullable(FixedString(1))'), 'Enum8(\'Hello\' = 1)'). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 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) @ 0x00000000091c4b52 5. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086d2b34 6. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008425b22 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601e5f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 2025.10.23 23:34:53.912881 [ 9434 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:34:54.752736 [ 4675 ] {d9d71079-9c15-49ae-ab4c-d57d88d62245} executeQuery: Code: 252. DB::Exception: Too many partitions for single INSERT block (more than 1). The limit is controlled by 'max_partitions_per_insert_block' setting. Large number of partitions is a common misconception. It will lead to severe negative performance impact, including slow server startup, slow INSERT queries and slow SELECT queries. Recommended total number of partitions for a table is under 1000..10000. Please note, that partitioning is not intended to speed up SELECT queries (ORDER BY key is sufficient to make range queries fast). Partitions are intended for data manipulation (DROP PARTITION, etc). (TOO_MANY_PARTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44428) (comment: 00930_max_partitions_per_insert_block.sql) (in query: INSERT INTO partitions SELECT * FROM system.numbers LIMIT 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000a7e012a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:98: DB::MergeTreeDataWriter::splitBlockIntoParts(DB::Block&&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr) @ 0x0000000039f1065b 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:0: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a3bd0fe 6. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bb51384 7. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b82a9a9 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b82a4b6 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b829167 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:57: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aea17d9 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:34:54.754396 [ 4675 ] {d9d71079-9c15-49ae-ab4c-d57d88d62245} TCPHandler: Code: 252. DB::Exception: Too many partitions for single INSERT block (more than 1). The limit is controlled by 'max_partitions_per_insert_block' setting. Large number of partitions is a common misconception. It will lead to severe negative performance impact, including slow server startup, slow INSERT queries and slow SELECT queries. Recommended total number of partitions for a table is under 1000..10000. Please note, that partitioning is not intended to speed up SELECT queries (ORDER BY key is sufficient to make range queries fast). Partitions are intended for data manipulation (DROP PARTITION, etc). (TOO_MANY_PARTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000a7e012a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:98: DB::MergeTreeDataWriter::splitBlockIntoParts(DB::Block&&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr) @ 0x0000000039f1065b 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:0: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a3bd0fe 6. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bb51384 7. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b82a9a9 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b82a4b6 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b829167 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:57: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aea17d9 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:34:54.839350 [ 9336 ] {} test_15.partitions (e242952a-6184-4794-96f7-e93109631709): dropAllData: got exception removing parts from disk, removing successfully removed parts from memory. 2025.10.23 23:34:54.972940 [ 9558 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:34:56.025191 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:34:56.529348 [ 7652 ] {13f1ffdc-9ccf-4680-801b-ccfde4b8991e} executeQuery: Code: 407. DB::Exception: DateTime64 convert overflow. Float is out of Decimal range: In scope SELECT toDateTime64(9300000000., 9, 'UTC'). (DECIMAL_OVERFLOW) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44516) (comment: 01734_datetime64_from_float.sql) (in query: SELECT toDateTime64(9300000000.0, 9, 'UTC');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008460d8a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:288: _ZN2DB20convertToDecimalImplINS_14DataTypeNumberIdEENS_18DataTypeDateTime64EvQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEET1_RKS5_jRNS6_9FieldTypeE @ 0x000000003250533b 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:322: _ZN2DB16convertToDecimalINS_14DataTypeNumberIdEENS_18DataTypeDateTime64EQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEENS6_9FieldTypeERKS5_j @ 0x000000003250a5b5 6. COW::immutable_ptr DB::DateTimeTransformImpl, DB::DataTypeDateTime64, DB::(anonymous namespace)::ToDateTime64TransformFloat, double, (DB::FormatSettings::DateTimeOverflowBehavior)0>, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::(anonymous namespace)::ToDateTime64TransformFloat, double, (DB::FormatSettings::DateTimeOverflowBehavior)0> const&) @ 0x0000000008eab33b 7. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000009394dd4 8. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009386d5c 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 17. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 20. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 2025.10.23 23:34:56.530212 [ 7652 ] {13f1ffdc-9ccf-4680-801b-ccfde4b8991e} TCPHandler: Code: 407. DB::Exception: DateTime64 convert overflow. Float is out of Decimal range: In scope SELECT toDateTime64(9300000000., 9, 'UTC'). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008460d8a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:288: _ZN2DB20convertToDecimalImplINS_14DataTypeNumberIdEENS_18DataTypeDateTime64EvQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEET1_RKS5_jRNS6_9FieldTypeE @ 0x000000003250533b 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:322: _ZN2DB16convertToDecimalINS_14DataTypeNumberIdEENS_18DataTypeDateTime64EQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEENS6_9FieldTypeERKS5_j @ 0x000000003250a5b5 6. COW::immutable_ptr DB::DateTimeTransformImpl, DB::DataTypeDateTime64, DB::(anonymous namespace)::ToDateTime64TransformFloat, double, (DB::FormatSettings::DateTimeOverflowBehavior)0>, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::(anonymous namespace)::ToDateTime64TransformFloat, double, (DB::FormatSettings::DateTimeOverflowBehavior)0> const&) @ 0x0000000008eab33b 7. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000009394dd4 8. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009386d5c 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 17. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 20. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 2025.10.23 23:34:56.779998 [ 9336 ] {} DatabaseCatalog: Cannot drop table test_15.partitions (e242952a-6184-4794-96f7-e93109631709). Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=17, jobs=17). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::clearPartsFromFilesystemImpl(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>*) @ 0x0000000039746581 8. ./contrib/llvm-project/libcxx/include/__hash_table:935: DB::MergeTreeData::clearPartsFromFilesystem(std::vector, std::allocator>> const&, bool, std::unordered_set, std::equal_to, std::allocator>*) @ 0x000000003973f352 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3004: DB::MergeTreeData::dropAllData() @ 0x0000000039755a8a 10. ./build_docker/./src/Storages/StorageMergeTree.cpp:317: DB::StorageMergeTree::drop() @ 0x000000003a2f1c13 11. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x00000000339c9eb0 12. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: void std::__function::__policy_invoker::__call_impl, std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000339ec8c3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000303f120c 14. ./contrib/llvm-project/libcxx/include/future:1694: std::__packaged_task_func>, std::function>::operator()(std::function&&, Priority)::'lambda'(), std::allocator>, std::function>::operator()(std::function&&, Priority)::'lambda'()>, void ()>::operator()() @ 0x00000000303f0fed 15. ./contrib/llvm-project/libcxx/include/future:2069: std::packaged_task::operator()() @ 0x00000000214b57dd 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000303f36ee 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 22. ? @ 0x00007f100c857ac3 23. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:57.070796 [ 9558 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:34:58.052454 [ 7652 ] {92a75bff-f9a9-4050-9eee-240f701cfc29} executeQuery: Code: 407. DB::Exception: Decimal math overflow: In scope SELECT toDateTime64(9300000000, 9, 'UTC'). (DECIMAL_OVERFLOW) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44516) (comment: 01734_datetime64_from_float.sql) (in query: SELECT toDateTime64(9300000000, 9, 'UTC');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. bool DB::DecimalUtils::multiplyAdd(long const&, long const&, long const&, long&) @ 0x0000000008678592 5. COW::immutable_ptr DB::DateTimeTransformImpl, DB::DataTypeDateTime64, DB::(anonymous namespace)::ToDateTime64TransformUnsigned, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::(anonymous namespace)::ToDateTime64TransformUnsigned const&) @ 0x0000000008ea4f4a 6. 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&&) @ 0x00000000093be4d1 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009386d5c 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:34:58.053458 [ 7652 ] {92a75bff-f9a9-4050-9eee-240f701cfc29} TCPHandler: Code: 407. DB::Exception: Decimal math overflow: In scope SELECT toDateTime64(9300000000, 9, 'UTC'). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. bool DB::DecimalUtils::multiplyAdd(long const&, long const&, long const&, long&) @ 0x0000000008678592 5. COW::immutable_ptr DB::DateTimeTransformImpl, DB::DataTypeDateTime64, DB::(anonymous namespace)::ToDateTime64TransformUnsigned, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::(anonymous namespace)::ToDateTime64TransformUnsigned const&) @ 0x0000000008ea4f4a 6. 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&&) @ 0x00000000093be4d1 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009386d5c 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:34:58.099683 [ 9558 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:34:59.160453 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:35:00.209428 [ 9558 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:35:01.249038 [ 9558 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:35:01.788597 [ 9262 ] {} test_15.partitions (e242952a-6184-4794-96f7-e93109631709): dropAllData: got exception removing parts from disk, removing successfully removed parts from memory. 2025.10.23 23:35:01.792080 [ 9262 ] {} DatabaseCatalog: Cannot drop table test_15.partitions (e242952a-6184-4794-96f7-e93109631709). Will retry later.: 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::clearPartsFromFilesystemImpl(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>*) @ 0x0000000039746581 8. ./contrib/llvm-project/libcxx/include/__hash_table:935: DB::MergeTreeData::clearPartsFromFilesystem(std::vector, std::allocator>> const&, bool, std::unordered_set, std::equal_to, std::allocator>*) @ 0x000000003973f352 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3004: DB::MergeTreeData::dropAllData() @ 0x0000000039755a8a 10. ./build_docker/./src/Storages/StorageMergeTree.cpp:317: DB::StorageMergeTree::drop() @ 0x000000003a2f1c13 11. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x00000000339c9eb0 12. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: void std::__function::__policy_invoker::__call_impl, std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000339ec8c3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000303f120c 14. ./contrib/llvm-project/libcxx/include/future:1694: std::__packaged_task_func>, std::function>::operator()(std::function&&, Priority)::'lambda'(), std::allocator>, std::function>::operator()(std::function&&, Priority)::'lambda'()>, void ()>::operator()() @ 0x00000000303f0fed 15. ./contrib/llvm-project/libcxx/include/future:2069: std::packaged_task::operator()() @ 0x00000000214b57dd 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000303f36ee 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 22. ? @ 0x00007f100c857ac3 23. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:02.284451 [ 9558 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:35:02.346714 [ 3654 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {26a86919-b755-436d-800b-c04857d425d1::202510_1_42_10}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 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) @ 0x0000000039c89948 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000003999bfb7 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 @ 0x00000000399942f0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000039d15c04 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&) @ 0x0000000039d20399 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) @ 0x0000000039d1c606 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000396308a4 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x00000000396235dd 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000003963b3e0 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x00000000396504a0 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3c455d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:03.333858 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:35:04.369091 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:35:05.456522 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:35:05.948930 [ 3334 ] {} test_3.rmt (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.10.23 23:35:05.948945 [ 3396 ] {} test_3.`02691_drop_column_replicated` (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.10.23 23:35:05.949078 [ 3359 ] {} test_15.r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.10.23 23:35:05.950680 [ 3318 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000003cc8de51 3. ./src/Common/ZooKeeper/IKeeper.h:509: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003cd16a3e 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003cd2369f 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe6e6d 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe5f26 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe84e7 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe81ea 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000003a10064e 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000003889f11d 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f9f 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:06.545868 [ 9453 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:35:06.849384 [ 3501 ] {} test_3.rmt (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /test/02253/02253_empty_part_checksums_test_3/rmt/log. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x0000000030538e6c 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000003cbf3b60 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003cbea871 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000003a0439c9 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a04133c 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:50: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a03dd98 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003a06697f 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:06.904192 [ 9343 ] {} test_15.partitions (e242952a-6184-4794-96f7-e93109631709): dropAllData: got exception removing parts from disk, removing successfully removed parts from memory. 2025.10.23 23:35:06.906602 [ 9343 ] {} DatabaseCatalog: Cannot drop table test_15.partitions (e242952a-6184-4794-96f7-e93109631709). Will retry later.: 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::clearPartsFromFilesystemImpl(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>*) @ 0x0000000039746581 8. ./contrib/llvm-project/libcxx/include/__hash_table:935: DB::MergeTreeData::clearPartsFromFilesystem(std::vector, std::allocator>> const&, bool, std::unordered_set, std::equal_to, std::allocator>*) @ 0x000000003973f352 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3004: DB::MergeTreeData::dropAllData() @ 0x0000000039755a8a 10. ./build_docker/./src/Storages/StorageMergeTree.cpp:317: DB::StorageMergeTree::drop() @ 0x000000003a2f1c13 11. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x00000000339c9eb0 12. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: void std::__function::__policy_invoker::__call_impl, std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000339ec8c3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000303f120c 14. ./contrib/llvm-project/libcxx/include/future:1694: std::__packaged_task_func>, std::function>::operator()(std::function&&, Priority)::'lambda'(), std::allocator>, std::function>::operator()(std::function&&, Priority)::'lambda'()>, void ()>::operator()() @ 0x00000000303f0fed 15. ./contrib/llvm-project/libcxx/include/future:2069: std::packaged_task::operator()() @ 0x00000000214b57dd 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000303f36ee 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 22. ? @ 0x00007f100c857ac3 23. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:07.101098 [ 3340 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02725_start_stop_fetches_test_15/r/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:07.300197 [ 7652 ] {caebe929-e962-4822-87fc-b9a977e4008a} executeQuery: Code: 999. Coordination::Exception: Coordination error: Connection loss, path /test/db/test_11/max_log_ptr. (KEEPER_EXCEPTION) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:34652) (comment: 03166_skip_indexes_vertical_merge_1.sql) (in query: CREATE TABLE t_ind_merge_1 (`a` UInt64, `b` UInt64, `c` UInt64, `d` UInt64, INDEX idx_b b TYPE minmax GRANULARITY 1) ENGINE = MergeTree ORDER BY a SETTINGS index_granularity = 64, merge_max_block_size = 8192, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_bytes_for_wide_part = 0, min_bytes_for_full_part_storage = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 58, compact_parts_max_bytes_to_buffer = 37060080, compact_parts_max_granules_to_buffer = 148, compact_parts_merge_max_bytes_to_prefetch_part = 11460946, old_parts_lifetime = 456., prefer_fetch_merged_part_size_threshold = 10737418240, min_merge_bytes_to_use_direct_io = 4194082082, index_granularity_bytes = 19277612, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 37264, primary_key_compress_block_size = 15642), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x0000000030538e6c 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000003cbf6898 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003cbf5ab3 6. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ad5036 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a52a3c 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfab2 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:35:07.302671 [ 7652 ] {caebe929-e962-4822-87fc-b9a977e4008a} TCPHandler: Code: 999. Coordination::Exception: Coordination error: Connection loss, path /test/db/test_11/max_log_ptr. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x0000000030538e6c 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000003cbf6898 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003cbf5ab3 6. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ad5036 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a52a3c 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfab2 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:35:07.528531 [ 9558 ] {8222cb51-c744-4cdc-a5e2-a30bdc6cf588} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=765, jobs=731). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:36884) (comment: 02020_alter_table_modify_comment.sh) (in query: SHOW CREATE TABLE comment_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:35:07.529895 [ 9558 ] {8222cb51-c744-4cdc-a5e2-a30bdc6cf588} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=765, jobs=731). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:35:07.573747 [ 9453 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:35:07.764089 [ 3501 ] {} test_3.rmt (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000003cc8de51 3. ./src/Common/ZooKeeper/IKeeper.h:509: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003cd16a3e 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000003cd20792 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryExistsNoThrow(String const&, std::function) @ 0x000000003cbf3581 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003cbf26a1 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000003cbf3a70 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003cbea871 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000003a0439c9 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a04133c 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:50: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a03dd98 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003a06697f 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 15. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:08.706555 [ 9453 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:35:09.803995 [ 9558 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:35:10.882054 [ 9453 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:35:11.993427 [ 8267 ] {} test_15.partitions (e242952a-6184-4794-96f7-e93109631709): dropAllData: got exception removing parts from disk, removing successfully removed parts from memory. 2025.10.23 23:35:11.995575 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:35:13.078110 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:35:13.949129 [ 8267 ] {} DatabaseCatalog: Cannot drop table test_15.partitions (e242952a-6184-4794-96f7-e93109631709). Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=22, jobs=22). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::clearPartsFromFilesystemImpl(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>*) @ 0x0000000039746581 8. ./contrib/llvm-project/libcxx/include/__hash_table:935: DB::MergeTreeData::clearPartsFromFilesystem(std::vector, std::allocator>> const&, bool, std::unordered_set, std::equal_to, std::allocator>*) @ 0x000000003973f352 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3004: DB::MergeTreeData::dropAllData() @ 0x0000000039755a8a 10. ./build_docker/./src/Storages/StorageMergeTree.cpp:317: DB::StorageMergeTree::drop() @ 0x000000003a2f1c13 11. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x00000000339c9eb0 12. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: void std::__function::__policy_invoker::__call_impl, std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000339ec8c3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000303f120c 14. ./contrib/llvm-project/libcxx/include/future:1694: std::__packaged_task_func>, std::function>::operator()(std::function&&, Priority)::'lambda'(), std::allocator>, std::function>::operator()(std::function&&, Priority)::'lambda'()>, void ()>::operator()() @ 0x00000000303f0fed 15. ./contrib/llvm-project/libcxx/include/future:2069: std::packaged_task::operator()() @ 0x00000000214b57dd 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000303f36ee 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 22. ? @ 0x00007f100c857ac3 23. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:14.189583 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:35:14.213376 [ 9453 ] {b720dc91-058d-4b10-bbb2-08c2912f1c24} executeQuery: Code: 57. DB::Exception: Table test_3hv5xr8k.comment_test_table already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37014) (comment: 02020_alter_table_modify_comment.sh) (in query: CREATE TABLE comment_test_table ( k UInt64, s String ) ENGINE = MergeTree() ORDER BY k COMMENT 'Test table with comment';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:35:14.216080 [ 9453 ] {b720dc91-058d-4b10-bbb2-08c2912f1c24} TCPHandler: Code: 57. DB::Exception: Table test_3hv5xr8k.comment_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:35:15.280052 [ 9453 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:35:16.346311 [ 9453 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:35:17.514885 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:35:18.573291 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:35:19.683668 [ 4745 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:35:20.624313 [ 7565 ] {f6256537-51f0-466b-b1ec-6342e408fc5f} 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.10542.altinitytest (altinity build)) (from [::1]:53688) (comment: 00751_default_databasename_for_view.sql) (in query: DETACH TABLE test_11.t_mv_00751), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:979: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000032a50c33 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a51799 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:222: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003493e6e9 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:35:20.626412 [ 7565 ] {f6256537-51f0-466b-b1ec-6342e408fc5f} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:979: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000032a50c33 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a51799 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:222: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003493e6e9 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:35:20.767325 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:35:21.821738 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:35:21.912690 [ 4745 ] {ef5a23bf-7e4e-46ac-a8a3-261938cbd376} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:53748) (comment: 00702_join_with_using_dups.sql) (in query: select s.*, j.* from (select * from X) as s left join (select * from Y) as j using id order by s.id, j.id, s.x_name, j.y_name;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:35:21.919104 [ 4745 ] {ef5a23bf-7e4e-46ac-a8a3-261938cbd376} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:35:22.055494 [ 9453 ] {8c27a638-5df4-484a-9fc0-62bc7a346372} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=765, jobs=731). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:53754) (comment: 02381_join_dup_columns_in_plan.gen.sql) (in query: SELECT * FROM ( SELECT number, number, number, number, number FROM numbers(5) ) as t1 FULL JOIN ( SELECT number, number, number, FROM numbers(3, 8) ) as t2 ON t1.number = t2.number ORDER BY t1.number, t2.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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:35:22.059213 [ 9453 ] {8c27a638-5df4-484a-9fc0-62bc7a346372} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=765, jobs=731). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:35:22.905143 [ 4745 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:35:23.619837 [ 9453 ] {8c95c1bc-e1fd-4608-977a-f29bf876e16b} executeQuery: Code: 57. DB::Exception: Table test_15.t already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:53806) (comment: 01201_read_single_thread_in_order.sql) (in query: CREATE TABLE t (`number` UInt64) ENGINE = MergeTree ORDER BY number SETTINGS index_granularity = 128, ratio_of_defaults_for_sparse_serialization = 1., index_granularity_bytes = '10Mi', min_bytes_for_wide_part = 0, replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 174595852, compact_parts_max_bytes_to_buffer = 305660710, compact_parts_max_granules_to_buffer = 203, compact_parts_merge_max_bytes_to_prefetch_part = 21785970, merge_max_block_size = 1576, old_parts_lifetime = 160., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 655580, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 6783006828, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 36016, primary_key_compress_block_size = 76539), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:35:23.622354 [ 9453 ] {8c95c1bc-e1fd-4608-977a-f29bf876e16b} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:35:23.942315 [ 9453 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:35:25.008676 [ 9453 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:35:25.538908 [ 4745 ] {5898c676-42b6-49e6-9db3-1be676de3715} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=765, jobs=731). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:53848) (comment: 03035_dynamic_sorting.sql) (in query: select d2, dynamicType(d2), isDynamicElementInSharedData(d2) from test order by d2 nulls last;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:35:25.541894 [ 4745 ] {5898c676-42b6-49e6-9db3-1be676de3715} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=765, jobs=731). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:35:25.560595 [ 4841 ] {14f6ccf4-99f6-4628-aea3-27b37dc89643} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=5, jobs=5). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:53864) (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:35:25.576946 [ 4841 ] {14f6ccf4-99f6-4628-aea3-27b37dc89643} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=5, jobs=5). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:35:26.054868 [ 9453 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:35:27.092921 [ 4745 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:35:28.203596 [ 9453 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:35:28.438936 [ 9453 ] {cccb0b6b-3615-463d-ad43-849a5fd4db91} executeQuery: Code: 57. DB::Exception: Table test_15.test already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:35120) (comment: 02941_variant_type_alters.sh) (in query: create table test (x UInt64, y 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:35:28.442286 [ 9453 ] {cccb0b6b-3615-463d-ad43-849a5fd4db91} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:35:29.217351 [ 9453 ] {7fde92fe-c36f-4295-802c-199b47d8bc2e} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:35150) (comment: 02941_variant_type_alters.sh) (in query: insert into test select number, number from numbers(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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 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*) @ 0x000000003aea17d9 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:35:29.222236 [ 9453 ] {7fde92fe-c36f-4295-802c-199b47d8bc2e} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 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*) @ 0x000000003aea17d9 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:35:29.252191 [ 4745 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:35:30.320853 [ 4745 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:35:30.569327 [ 9453 ] {9ffa4beb-478c-4edb-9fc0-19d67a091912} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'x' in scope SELECT x, y, v, v.String, v.UInt64 FROM test ORDER BY x ASC. Maybe you meant: ['v']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:35200) (comment: 02941_variant_type_alters.sh) (in query: select x, y, v, v.String, v.UInt64 from test 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000335017e7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003345512b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:35:30.571208 [ 9453 ] {9ffa4beb-478c-4edb-9fc0-19d67a091912} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'x' in scope SELECT x, y, v, v.String, v.UInt64 FROM test ORDER BY x ASC. Maybe you meant: ['v']. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000335017e7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003345512b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:35:31.399131 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:35:32.471289 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:35:33.553102 [ 4745 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:35:34.606855 [ 4745 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:35:35.246587 [ 4841 ] {538d1c4e-8edb-47a6-a9e4-11a2a7876433} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'x' in scope SELECT x, y, v, v.String, v.UInt64 FROM test ORDER BY x ASC. Maybe you meant: ['v']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:52638) (comment: 02941_variant_type_alters.sh) (in query: select x, y, v, v.String, v.UInt64 from test 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000335017e7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003345512b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:35:35.249996 [ 4841 ] {538d1c4e-8edb-47a6-a9e4-11a2a7876433} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'x' in scope SELECT x, y, v, v.String, v.UInt64 FROM test ORDER BY x ASC. Maybe you meant: ['v']. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000335017e7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003345512b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:35:35.682789 [ 4745 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:35:35.857851 [ 3403 ] {} test_3.`02691_drop_column_replicated` (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.10.23 23:35:35.858083 [ 3394 ] {} test_3.rmt (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.10.23 23:35:35.858201 [ 3406 ] {} test_15.r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.10.23 23:35:35.859787 [ 4752 ] {9dda0210-099f-4265-bc18-a03389a590da} executeQuery: Code: 999. Coordination::Exception: Coordination error: Connection loss, path /test/db/test_11/max_log_ptr. (KEEPER_EXCEPTION) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:35126) (comment: 00937_template_output_format.sh) (in query: CREATE TABLE template (s1 String, s2 String, `s 3` String, "s 4" String, n UInt64, d Date) 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x0000000030538e6c 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000003cbf6898 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003cbf5ab3 6. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ad5036 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a52a3c 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfab2 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:35:35.861065 [ 3440 ] {} test_3.`02691_drop_column_replicated` (1045b1a8-f37f-4f75-892a-b44e770b298b): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_3/test/02691_drop_column/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:35.861448 [ 3410 ] {} test_3.`02691_drop_column_replicated` (1045b1a8-f37f-4f75-892a-b44e770b298b): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000003cc8de51 3. ./src/Common/ZooKeeper/IKeeper.h:509: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003cd16a3e 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003cd2369f 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe6e6d 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe5f26 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe84e7 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe81ea 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000003a10064e 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000003889f11d 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f9f 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:35.861950 [ 4752 ] {9dda0210-099f-4265-bc18-a03389a590da} TCPHandler: Code: 999. Coordination::Exception: Coordination error: Connection loss, path /test/db/test_11/max_log_ptr. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x0000000030538e6c 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000003cbf6898 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003cbf5ab3 6. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ad5036 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a52a3c 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfab2 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:35:36.492254 [ 3143 ] {} test_3.rmt (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /test/02253/02253_empty_part_checksums_test_3/rmt/async_blocks. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x0000000030538e6c 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe8649 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000003cbe7761 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x000000003a061e9e 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x000000003a04fe19 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:165: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a04156e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:50: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a03dd98 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003a06697f 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:36.493662 [ 3143 ] {} test_3.rmt (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000003cc8de51 3. ./src/Common/ZooKeeper/IKeeper.h:509: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003cd16a3e 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000003cd20792 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryExistsNoThrow(String const&, std::function) @ 0x000000003cbf3581 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003cbf26a1 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000003cbf3a70 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003cbea871 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000003a0439c9 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a04133c 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:50: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a03dd98 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003a06697f 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 15. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:36.556740 [ 6961 ] {4711a581-4124-4dca-9497-c01d20587297} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'x' in scope SELECT x, y, v, v.String, v.UInt64, v.Date FROM test ORDER BY x ASC. Maybe you meant: ['v']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:52722) (comment: 02941_variant_type_alters.sh) (in query: select x, y, v, v.String, v.UInt64, v.Date from test 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000335017e7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003345512b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:35:36.558560 [ 6961 ] {4711a581-4124-4dca-9497-c01d20587297} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'x' in scope SELECT x, y, v, v.String, v.UInt64, v.Date FROM test ORDER BY x ASC. Maybe you meant: ['v']. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000335017e7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003345512b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:35:36.599515 [ 7759 ] {f75a5d64-e07b-4a84-a37c-ad6dc12e5533} executeQuery: Code: 60. DB::Exception: Table test_11.template does not exist. (UNKNOWN_TABLE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:52710) (comment: 00937_template_output_format.sh) (in query: INSERT INTO template 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b14381 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:433: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000003399fc33 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:957: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339b4ac1 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000034b9ec4f 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000034bb99c8 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:35:36.606784 [ 7759 ] {f75a5d64-e07b-4a84-a37c-ad6dc12e5533} TCPHandler: Code: 60. DB::Exception: Table test_11.template 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b14381 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:433: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000003399fc33 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:957: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339b4ac1 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000034b9ec4f 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000034bb99c8 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:35:36.711058 [ 3895 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:35:36.861817 [ 3280 ] {} test_3.`02691_drop_column_replicated` (1045b1a8-f37f-4f75-892a-b44e770b298b): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_3/test/02691_drop_column/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:37.272366 [ 3895 ] {c99a8e76-dfd7-4874-a3d1-1acfa57b3615} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'template' in scope SELECT * FROM template GROUP BY s1, s2, `s 3`, `s 4`, n, d WITH TOTALS ORDER BY n ASC LIMIT 4. (UNKNOWN_TABLE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:52754) (comment: 00937_template_output_format.sh) (in query: SELECT * FROM template GROUP BY s1, s2, `s 3`, "s 4", n, d WITH TOTALS ORDER BY n LIMIT 4 FORMAT Template SETTINGS extremes = 1,format_template_resultset = '/usr/share/clickhouse-test/queries/0_stateless/00937_template_output_format_resultset.tmp', format_template_row = '/usr/share/clickhouse-test/queries/0_stateless/00937_template_output_format_row.tmp', format_template_rows_between_delimiter = ';\n'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa0996d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334eae8a 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003343676d 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 2025.10.23 23:35:37.272887 [ 3397 ] {} test_3.`02691_drop_column_replicated` (1045b1a8-f37f-4f75-892a-b44e770b298b): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_3/test/02691_drop_column/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:37.274594 [ 3895 ] {c99a8e76-dfd7-4874-a3d1-1acfa57b3615} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'template' in scope SELECT * FROM template GROUP BY s1, s2, `s 3`, `s 4`, n, d WITH TOTALS ORDER BY n ASC LIMIT 4. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa0996d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334eae8a 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003343676d 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 2025.10.23 23:35:37.296600 [ 7759 ] {9f4cd864-4dd9-44c9-a7a6-54b92b9ab804} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:52760) (comment: 02941_variant_type_alters.sh) (in query: insert into test select number, number, toDate(number) from numbers(15, 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 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*) @ 0x000000003aea17d9 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:35:37.299888 [ 7759 ] {9f4cd864-4dd9-44c9-a7a6-54b92b9ab804} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 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*) @ 0x000000003aea17d9 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:35:37.659668 [ 3487 ] {} test_3.`02691_drop_column_replicated` (1045b1a8-f37f-4f75-892a-b44e770b298b): void DB::StorageReplicatedMergeTree::mergeSelectingTask(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/test_3/test/02691_drop_column/replicas/r1/log_pointer. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x0000000030538e6c 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000003cbf6898 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003cbf5ab3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x000000003a0eb80c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:2447: DB::ReplicatedMergeTreeMergePredicate::ReplicatedMergeTreeMergePredicate(DB::ReplicatedMergeTreeQueue&, std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x000000003a15e77f 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1899: DB::ReplicatedMergeTreeQueue::getMergePredicate(std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x000000003a14165c 9. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::mergeSelectingTask() @ 0x00000000388a7cf6 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6fdf 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:37.774608 [ 3895 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:35:37.920432 [ 3895 ] {b6e329cf-9600-4a51-bc8b-f47ed9d87110} executeQuery: Code: 60. DB::Exception: Table test_11.template does not exist. (UNKNOWN_TABLE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:52784) (comment: 00937_template_output_format.sh) (in query: DROP TABLE template), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b14381 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:433: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000003399fc33 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339b5107 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003493bddb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:35:37.923023 [ 3895 ] {b6e329cf-9600-4a51-bc8b-f47ed9d87110} TCPHandler: Code: 60. DB::Exception: Table test_11.template 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b14381 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:433: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000003399fc33 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339b5107 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003493bddb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:35:38.692817 [ 4841 ] {fb03cad7-6c7a-4bfe-bc2a-47e902b7f21a} executeQuery: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column '__table1.c' of type 'UInt64'. (INVALID_JOIN_ON_EXPRESSION) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:52692) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (in query: SELECT t1.*, t2.* from t1 LEFT JOIN t2 ON t1.key = t2.key and t1.c ORDER BY (t1.key, t1.attr, t2.key, t2.attr);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa0996d 4. ./build_docker/./src/Interpreters/JoinUtils.cpp:426: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x0000000034ec8b9f 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:431: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x0000000034ec83ed 6. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:0: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000035c4cb58 7. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:0: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x000000003b83f981 8. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:104: DB::JoinStep::updateOutputStream() @ 0x000000003be75c7a 9. ./src/Processors/QueryPlan/IQueryPlanStep.h:125: DB::IQueryPlanStep::updateInputStreams(std::vector>) @ 0x000000003be79984 10. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:0: DB::JoinStep::JoinStep(DB::DataStream const&, DB::DataStream const&, std::shared_ptr, unsigned long, unsigned long, bool) @ 0x000000003be726c2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h: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&) @ 0x0000000034d97139 12. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d6a797 13. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0b8de 14. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cfd8b2 15. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034cf6172 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5bf1 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:35:38.693974 [ 4841 ] {fb03cad7-6c7a-4bfe-bc2a-47e902b7f21a} TCPHandler: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column '__table1.c' of type 'UInt64'. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa0996d 4. ./build_docker/./src/Interpreters/JoinUtils.cpp:426: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x0000000034ec8b9f 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:431: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x0000000034ec83ed 6. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:0: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000035c4cb58 7. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:0: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x000000003b83f981 8. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:104: DB::JoinStep::updateOutputStream() @ 0x000000003be75c7a 9. ./src/Processors/QueryPlan/IQueryPlanStep.h:125: DB::IQueryPlanStep::updateInputStreams(std::vector>) @ 0x000000003be79984 10. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:0: DB::JoinStep::JoinStep(DB::DataStream const&, DB::DataStream const&, std::shared_ptr, unsigned long, unsigned long, bool) @ 0x000000003be726c2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h: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&) @ 0x0000000034d97139 12. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d6a797 13. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0b8de 14. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cfd8b2 15. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034cf6172 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5bf1 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:35:38.856103 [ 6961 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:35:39.025018 [ 2904 ] {1b576284-4af0-4d84-9933-1b12b2566c52} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'x' in scope SELECT x, y, v, v.String, v.UInt64, v.Date FROM test ORDER BY x ASC. Maybe you meant: ['v']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:52850) (comment: 02941_variant_type_alters.sh) (in query: select x, y, v, v.String, v.UInt64, v.Date from test 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000335017e7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003345512b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:35:39.028888 [ 2904 ] {1b576284-4af0-4d84-9933-1b12b2566c52} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'x' in scope SELECT x, y, v, v.String, v.UInt64, v.Date FROM test ORDER BY x ASC. Maybe you meant: ['v']. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000335017e7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003345512b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:35:39.932079 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:35:40.920676 [ 7759 ] {fa36c765-7d3d-49cd-bf94-933d8d4ba3a9} executeQuery: Code: 10. DB::Exception: Wrong column. Cannot find column `y` to modify. Maybe you meant: ['v']. (NOT_FOUND_COLUMN_IN_BLOCK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:52876) (comment: 02941_variant_type_alters.sh) (in query: alter table test modify column y Variant(UInt64, String) settings mutations_sync=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Storages/AlterCommands.cpp:1365: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000380b5d7b 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034866171 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003485e550 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:35:40.922410 [ 7759 ] {fa36c765-7d3d-49cd-bf94-933d8d4ba3a9} TCPHandler: Code: 10. DB::Exception: Wrong column. Cannot find column `y` to modify. Maybe you meant: ['v']. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Storages/AlterCommands.cpp:1365: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000380b5d7b 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034866171 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003485e550 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:35:40.995171 [ 6961 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:35:41.474035 [ 4841 ] {cee15fa1-c06b-4011-9dbc-27ab4b72a6c3} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:52692) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (in query: SELECT t1.*, t2.* from t1 INNER JOIN t2 ON t1.key = t2.key and (t1.b + t2.b == t1.c + t2.c) ORDER BY (t1.key, t1.attr, t2.key, t2.attr);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000039d07892 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&) @ 0x0000000039d09d4a 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:63: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x00000000326402a2 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000032640cad 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000039d01224 14. ./contrib/llvm-project/libcxx/include/vector:547: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000039d00b49 15. ./contrib/llvm-project/libcxx/include/__tree:1088: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) @ 0x00000000399bb1c8 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 @ 0x00000000399b0254 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039d45fb0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003bfd663a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c083c53 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003bfe2b53 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d3c440 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf89b85 23. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 24. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 28. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 31. ? @ 0x00007f100c857ac3 2025.10.23 23:35:41.478145 [ 4841 ] {cee15fa1-c06b-4011-9dbc-27ab4b72a6c3} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000039d07892 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&) @ 0x0000000039d09d4a 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:63: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x00000000326402a2 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000032640cad 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000039d01224 14. ./contrib/llvm-project/libcxx/include/vector:547: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000039d00b49 15. ./contrib/llvm-project/libcxx/include/__tree:1088: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) @ 0x00000000399bb1c8 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 @ 0x00000000399b0254 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039d45fb0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003bfd663a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c083c53 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003bfe2b53 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d3c440 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf89b85 23. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 24. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 28. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 31. ? @ 0x00007f100c857ac3 2025.10.23 23:35:41.501181 [ 7759 ] {fd1b2050-7299-4ba9-80d6-690ad6fe053b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:52938) (comment: 01381_for_each_with_states.sql) (in query: SELECT hex(toString(uniqStateForEachState([1, 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:35:41.503576 [ 7759 ] {fd1b2050-7299-4ba9-80d6-690ad6fe053b} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:35:41.602793 [ 7759 ] {e538d6de-3ad2-4ac4-9d4e-21555152c9fb} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37944) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (in query: DROP DATABASE IF EXISTS test_79ykqgig ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:35:41.604677 [ 7759 ] {e538d6de-3ad2-4ac4-9d4e-21555152c9fb} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:41.681031 [ 7759 ] {3ec479c6-cb5d-46c5-9101-238f1fc538d3} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'x' in scope SELECT x, y, y.UInt64, y.String, v, v.String, v.UInt64, v.Date FROM test ORDER BY x ASC. Maybe you meant: ['v']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:52944) (comment: 02941_variant_type_alters.sh) (in query: select x, y, y.UInt64, y.String, v, v.String, v.UInt64, v.Date from test 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000335017e7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003345512b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:35:41.682899 [ 7759 ] {3ec479c6-cb5d-46c5-9101-238f1fc538d3} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'x' in scope SELECT x, y, y.UInt64, y.String, v, v.String, v.UInt64, v.Date FROM test ORDER BY x ASC. Maybe you meant: ['v']. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000335017e7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003345512b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:35:42.095061 [ 7759 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:35:43.148384 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:35:43.563147 [ 7759 ] {917873e4-2f60-4b87-9556-9ad27bfa9e6c} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'x' in scope SELECT x, y, y.UInt64, y.String, v, v.String, v.UInt64, v.Date FROM test ORDER BY x ASC. Maybe you meant: ['v']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:53038) (comment: 02941_variant_type_alters.sh) (in query: select x, y, y.UInt64, y.String, v, v.String, v.UInt64, v.Date from test 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000335017e7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003345512b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:35:43.565504 [ 7759 ] {917873e4-2f60-4b87-9556-9ad27bfa9e6c} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'x' in scope SELECT x, y, y.UInt64, y.String, v, v.String, v.UInt64, v.Date FROM test ORDER BY x ASC. Maybe you meant: ['v']. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000335017e7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003345512b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:35:44.213304 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:35:45.076393 [ 7759 ] {4990ba33-4110-49e2-93ce-4f3ef99e0195} executeQuery: Code: 57. DB::Exception: Table test_15.test already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:46748) (comment: 02941_variant_type_alters.sh) (in query: CREATE TABLE test (`x` UInt64, `y` UInt64) ENGINE = MergeTree ORDER BY x SETTINGS min_rows_for_wide_part = 100000000, min_bytes_for_wide_part = 1000000000, index_granularity = 3456, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 82, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 22683924, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 8126184, merge_max_block_size = 1874, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 1052877313, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 7397672317, index_granularity_bytes = 22617599, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 63875, primary_key_compress_block_size = 54187), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:35:45.078437 [ 7759 ] {4990ba33-4110-49e2-93ce-4f3ef99e0195} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:35:45.260796 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:35:46.319911 [ 4712 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:35:46.508745 [ 9678 ] {dcb50c14-0b44-478d-8ba9-78e3bca2aae1} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:35616) (comment: 03205_parallel_replicas_alter_select_ubsan.sql) (in query: DROP DATABASE IF EXISTS test_txrubaor ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:35:46.510590 [ 9678 ] {dcb50c14-0b44-478d-8ba9-78e3bca2aae1} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:46.569598 [ 4712 ] {0ad09f18-ad6b-4b05-a31d-b10b385339c0} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:40818) (comment: 03205_parallel_replicas_alter_select_ubsan.sql) (in query: DROP DATABASE IF EXISTS test_txrubaor ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:35:46.571416 [ 4712 ] {0ad09f18-ad6b-4b05-a31d-b10b385339c0} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:46.591686 [ 7652 ] {e5aa18c1-7847-428f-aa08-45b07cf244f9} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:40820) (comment: 03205_parallel_replicas_alter_select_ubsan.sql) (in query: DROP DATABASE IF EXISTS test_txrubaor ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:35:46.594532 [ 7652 ] {e5aa18c1-7847-428f-aa08-45b07cf244f9} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:47.139439 [ 2904 ] {76ab102d-ca3f-49c0-bf34-609d3c199348} executeQuery: Code: 20. DB::Exception: Number of columns doesn't match (source: 2 and result: 3). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:46794) (comment: 02941_variant_type_alters.sh) (in query: insert into test select number, number from numbers(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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b989f4d 4. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1464: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000033273bcf 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034bb0883 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034bbac4c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:35:47.142306 [ 2904 ] {76ab102d-ca3f-49c0-bf34-609d3c199348} TCPHandler: Code: 20. DB::Exception: Number of columns doesn't match (source: 2 and result: 3). (NUMBER_OF_COLUMNS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b989f4d 4. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1464: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000033273bcf 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034bb0883 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034bbac4c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:35:47.410415 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:35:48.227643 [ 9763 ] {} ZooKeeperClient: Code: 999. Coordination::Exception: Session expired (fault injected on recv). (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000003a21d8b1 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEES0_NS_5ErrorEOS5_ @ 0x000000003cd2cd64 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1660: Coordination::ZooKeeper::maybeInjectRecvFault() @ 0x000000003cd156a2 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveEvent() @ 0x000000003cd1207c 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveThread() @ 0x000000003cd109b9 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl> const&, zkutil::ZooKeeperArgs const&, std::shared_ptr)::$_1>(Coordination::ZooKeeper::ZooKeeper(std::vector> const&, zkutil::ZooKeeperArgs const&, std::shared_ptr)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003cd2940f 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:48.229453 [ 3128 ] {} test_3.`02691_drop_column_replicated` (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.10.23 23:35:48.229670 [ 3138 ] {} test_3.rmt (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.10.23 23:35:48.229831 [ 3126 ] {} test_15.r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.10.23 23:35:48.230284 [ 3156 ] {} test_3.rmt (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /test/02253/02253_empty_part_checksums_test_3/rmt/log. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x0000000030538e6c 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000003cbf3b60 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003cbea871 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000003a0439c9 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a04133c 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:50: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a03dd98 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003a06697f 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:48.231527 [ 3156 ] {} test_3.rmt (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000003cc8de51 3. ./src/Common/ZooKeeper/IKeeper.h:509: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003cd16a3e 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000003cd20792 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryExistsNoThrow(String const&, std::function) @ 0x000000003cbf3581 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003cbf26a1 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000003cbf3a70 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003cbea871 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000003a0439c9 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a04133c 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:50: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a03dd98 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003a06697f 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 15. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:48.450343 [ 9558 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:35:48.912474 [ 4712 ] {db1f22fd-3e48-40b0-a0f5-1105929773a8} executeQuery: Code: 15. DB::Exception: Cannot add column `v`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:46894) (comment: 02941_variant_type_alters.sh) (in query: alter table test add column v Variant(UInt64, String) settings mutations_sync=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1321: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000380b4d24 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034866171 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003485e550 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:35:48.915375 [ 4712 ] {db1f22fd-3e48-40b0-a0f5-1105929773a8} TCPHandler: Code: 15. DB::Exception: Cannot add column `v`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1321: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000380b4d24 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034866171 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003485e550 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:35:49.514301 [ 4712 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:35:49.665152 [ 3894 ] {4b964d2c-ba18-4bdd-8010-12aba3c95a06} executeQuery: Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/02020_alter_table_modify_comment_test_3hv5xr8k. (KEEPER_EXCEPTION) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:46864) (comment: 02020_alter_table_modify_comment.sh) (in query: CREATE TABLE comment_test_table ( k UInt64, s String ) ENGINE = ReplicatedMergeTree('/clickhouse/02020_alter_table_modify_comment_test_3hv5xr8k', '1') ORDER BY k COMMENT 'Test table with comment';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x0000000030538e6c 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::createAncestors(String const&) @ 0x000000003cbed2da 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::createTableIfNotExists(std::shared_ptr const&) @ 0x00000000386fb602 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(String const&, String const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, DB::RenamingRestrictions, bool) @ 0x00000000386f4ccd 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, void>(std::allocator const&, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003a2e359e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2d2f53 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7b27a 10. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x0000000038308626 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348e414c 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 2025.10.23 23:35:49.667160 [ 3894 ] {4b964d2c-ba18-4bdd-8010-12aba3c95a06} TCPHandler: Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/02020_alter_table_modify_comment_test_3hv5xr8k. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x0000000030538e6c 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::createAncestors(String const&) @ 0x000000003cbed2da 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::createTableIfNotExists(std::shared_ptr const&) @ 0x00000000386fb602 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(String const&, String const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, DB::RenamingRestrictions, bool) @ 0x00000000386f4ccd 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, void>(std::allocator const&, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003a2e359e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2d2f53 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7b27a 10. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x0000000038308626 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348e414c 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 2025.10.23 23:35:49.695165 [ 4712 ] {6534f8f4-6179-4cde-82b8-ae955611e14b} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'x' in scope SELECT x, y, v, v.String, v.UInt64 FROM test ORDER BY x ASC. Maybe you meant: ['v']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:46960) (comment: 02941_variant_type_alters.sh) (in query: select x, y, v, v.String, v.UInt64 from test 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000335017e7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003345512b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:35:49.697052 [ 4712 ] {6534f8f4-6179-4cde-82b8-ae955611e14b} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'x' in scope SELECT x, y, v, v.String, v.UInt64 FROM test ORDER BY x ASC. Maybe you meant: ['v']. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000335017e7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003345512b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:35:50.573894 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:35:50.964003 [ 2904 ] {ac5970e8-8412-4f0b-95bf-debdcd21f65b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=0): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:46904) (comment: 00193_parallel_replicas.sql) (in query: INSERT INTO parallel_replicas_backup(d, x, u, s) SELECT d, x, u, s FROM parallel_replicas;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 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) @ 0x0000000039c89948 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000003999bfb7 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 @ 0x00000000399942f0 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039d45fb0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003bfd663a 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:146: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c06c954 15. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:37: DB::MergeTreeThreadSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003bf806f4 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d3c440 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf89b85 18. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 19. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 25. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 27. ? @ 0x00007f100c857ac3 28. ? @ 0x00007f100c8e9850 2025.10.23 23:35:50.967510 [ 2904 ] {ac5970e8-8412-4f0b-95bf-debdcd21f65b} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 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) @ 0x0000000039c89948 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000003999bfb7 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 @ 0x00000000399942f0 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039d45fb0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003bfd663a 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:146: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c06c954 15. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:37: DB::MergeTreeThreadSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003bf806f4 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d3c440 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf89b85 18. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 19. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 25. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 27. ? @ 0x00007f100c857ac3 28. ? @ 0x00007f100c8e9850 2025.10.23 23:35:50.991927 [ 4712 ] {c67c4820-77e2-4ae3-a72a-6501e523d38e} executeQuery: Code: 390. DB::Exception: Table `comment_test_table` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:46978) (comment: 02020_alter_table_modify_comment.sh) (in query: SHOW CREATE TABLE comment_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000032960fc6 5. ./src/Databases/IDatabase.h:0: DB::InterpreterShowCreateQuery::executeImpl() @ 0x00000000359e1aac 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x00000000359e0c24 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:35:50.993736 [ 4712 ] {c67c4820-77e2-4ae3-a72a-6501e523d38e} TCPHandler: Code: 390. DB::Exception: Table `comment_test_table` 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000032960fc6 5. ./src/Databases/IDatabase.h:0: DB::InterpreterShowCreateQuery::executeImpl() @ 0x00000000359e1aac 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x00000000359e0c24 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:35:51.006290 [ 3894 ] {22d6d5b6-6e1c-4d3e-924b-aaf42b546990} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:46988) (comment: 02941_variant_type_alters.sh) (in query: insert into test select number, number, number from numbers(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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 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*) @ 0x000000003aea17d9 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:35:51.009190 [ 3894 ] {22d6d5b6-6e1c-4d3e-924b-aaf42b546990} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 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*) @ 0x000000003aea17d9 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:35:51.058587 [ 2904 ] {19065a59-55fc-45e9-9de9-1334704b044f} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:40856) (comment: 00193_parallel_replicas.sql) (in query: DROP DATABASE IF EXISTS test_9bgpmz11 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:35:51.060472 [ 2904 ] {19065a59-55fc-45e9-9de9-1334704b044f} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:51.599178 [ 2903 ] {fcaf0309-c2df-4b1b-9e75-04d0e7e66618} executeQuery: Code: 457. DB::Exception: Value [1] OR 1 cannot be parsed as Array(UInt32) for query parameter 'injection' because it isn't parsed completely: only 3 of 8 bytes was parsed: [1]. (BAD_QUERY_PARAMETER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:46996) (comment: 00955_complex_prepared_statements.sh) (in query: SELECT * FROM ps WHERE a = {injection:Array(UInt32)}), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String const&, String const&, unsigned long&&, unsigned long&&, String&&) @ 0x00000000358565a7 4. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:104: DB::ReplaceQueryParameterVisitor::visitQueryParameter(std::shared_ptr&) @ 0x0000000035854447 5. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:0: DB::ReplaceQueryParameterVisitor::visit(std::shared_ptr&) @ 0x0000000035851816 6. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:0: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000358555d2 7. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:48: DB::ReplaceQueryParameterVisitor::visit(std::shared_ptr&) @ 0x0000000035851a17 8. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:0: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000358555d2 9. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:48: DB::ReplaceQueryParameterVisitor::visit(std::shared_ptr&) @ 0x0000000035851a17 10. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:0: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000358555d2 11. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:48: DB::ReplaceQueryParameterVisitor::visit(std::shared_ptr&) @ 0x0000000035851a17 12. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:0: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000358555d2 13. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:48: DB::ReplaceQueryParameterVisitor::visit(std::shared_ptr&) @ 0x0000000035851a17 14. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:0: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000358555d2 15. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:48: DB::ReplaceQueryParameterVisitor::visit(std::shared_ptr&) @ 0x0000000035851a17 16. ./src/Interpreters/ReplaceQueryParameterVisitor.h:23: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358ae427 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:35:51.601180 [ 2903 ] {fcaf0309-c2df-4b1b-9e75-04d0e7e66618} TCPHandler: Code: 457. DB::Exception: Value [1] OR 1 cannot be parsed as Array(UInt32) for query parameter 'injection' because it isn't parsed completely: only 3 of 8 bytes was parsed: [1]. (BAD_QUERY_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String const&, String const&, unsigned long&&, unsigned long&&, String&&) @ 0x00000000358565a7 4. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:104: DB::ReplaceQueryParameterVisitor::visitQueryParameter(std::shared_ptr&) @ 0x0000000035854447 5. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:0: DB::ReplaceQueryParameterVisitor::visit(std::shared_ptr&) @ 0x0000000035851816 6. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:0: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000358555d2 7. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:48: DB::ReplaceQueryParameterVisitor::visit(std::shared_ptr&) @ 0x0000000035851a17 8. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:0: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000358555d2 9. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:48: DB::ReplaceQueryParameterVisitor::visit(std::shared_ptr&) @ 0x0000000035851a17 10. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:0: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000358555d2 11. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:48: DB::ReplaceQueryParameterVisitor::visit(std::shared_ptr&) @ 0x0000000035851a17 12. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:0: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000358555d2 13. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:48: DB::ReplaceQueryParameterVisitor::visit(std::shared_ptr&) @ 0x0000000035851a17 14. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:0: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000358555d2 15. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:48: DB::ReplaceQueryParameterVisitor::visit(std::shared_ptr&) @ 0x0000000035851a17 16. ./src/Interpreters/ReplaceQueryParameterVisitor.h:23: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358ae427 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:35:51.617645 [ 4675 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:35:52.650766 [ 4752 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:35:52.762518 [ 2904 ] {d160123c-e71c-4ea0-9bf1-124f5e203eb6} executeQuery: Code: 60. DB::Exception: Could not find table: comment_test_table. (UNKNOWN_TABLE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:47030) (comment: 02020_alter_table_modify_comment.sh) (in query: ALTER TABLE comment_test_table MODIFY COMMENT 'new comment on a 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000842350a 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034869c28 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003485e550 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 2025.10.23 23:35:52.764371 [ 2904 ] {d160123c-e71c-4ea0-9bf1-124f5e203eb6} TCPHandler: Code: 60. DB::Exception: Could not find table: comment_test_table. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000842350a 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034869c28 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003485e550 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 2025.10.23 23:35:53.360463 [ 7565 ] {0452bf14-5dab-4b5e-b8fb-e1ada3b7b5d0} executeQuery: Code: 390. DB::Exception: Table `comment_test_table` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:47076) (comment: 02020_alter_table_modify_comment.sh) (in query: SHOW CREATE TABLE comment_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000032960fc6 5. ./src/Databases/IDatabase.h:0: DB::InterpreterShowCreateQuery::executeImpl() @ 0x00000000359e1aac 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x00000000359e0c24 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:35:53.362405 [ 7565 ] {0452bf14-5dab-4b5e-b8fb-e1ada3b7b5d0} TCPHandler: Code: 390. DB::Exception: Table `comment_test_table` 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000032960fc6 5. ./src/Databases/IDatabase.h:0: DB::InterpreterShowCreateQuery::executeImpl() @ 0x00000000359e1aac 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x00000000359e0c24 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:35:53.699635 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:35:54.299882 [ 2904 ] {f84fc95a-75a2-49e9-9b5a-b7334b4c18de} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'x' in scope SELECT x, y, v, v.String, v.UInt64 FROM test ORDER BY x ASC. Maybe you meant: ['v']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:47118) (comment: 02941_variant_type_alters.sh) (in query: select x, y, v, v.String, v.UInt64 from test 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000335017e7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003345512b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:35:54.301699 [ 2904 ] {f84fc95a-75a2-49e9-9b5a-b7334b4c18de} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'x' in scope SELECT x, y, v, v.String, v.UInt64 FROM test ORDER BY x ASC. Maybe you meant: ['v']. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000335017e7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003345512b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:35:54.542405 [ 2904 ] {a9c1f58b-ae17-419e-8d73-42c538a893dd} executeQuery: Code: 60. DB::Exception: Could not find table: comment_test_table. (UNKNOWN_TABLE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:47134) (comment: 02020_alter_table_modify_comment.sh) (in query: ALTER TABLE comment_test_table MODIFY COMMENT '';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000842350a 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034869c28 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003485e550 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 2025.10.23 23:35:54.544322 [ 2904 ] {a9c1f58b-ae17-419e-8d73-42c538a893dd} TCPHandler: Code: 60. DB::Exception: Could not find table: comment_test_table. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000842350a 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034869c28 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003485e550 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 2025.10.23 23:35:54.780684 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:35:55.180556 [ 2904 ] {800d3f14-b614-475f-b52d-767267d0e06a} executeQuery: Code: 390. DB::Exception: Table `comment_test_table` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:55012) (comment: 02020_alter_table_modify_comment.sh) (in query: SHOW CREATE TABLE comment_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000032960fc6 5. ./src/Databases/IDatabase.h:0: DB::InterpreterShowCreateQuery::executeImpl() @ 0x00000000359e1aac 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x00000000359e0c24 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:35:55.182197 [ 2904 ] {800d3f14-b614-475f-b52d-767267d0e06a} TCPHandler: Code: 390. DB::Exception: Table `comment_test_table` 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000032960fc6 5. ./src/Databases/IDatabase.h:0: DB::InterpreterShowCreateQuery::executeImpl() @ 0x00000000359e1aac 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x00000000359e0c24 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:35:55.579349 [ 2904 ] {63e11338-8a54-4419-bcb2-cf611a2983e8} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'x' in scope SELECT x, y, v, v.String, v.UInt64, v.Date FROM test ORDER BY x ASC. Maybe you meant: ['v']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:55018) (comment: 02941_variant_type_alters.sh) (in query: select x, y, v, v.String, v.UInt64, v.Date from test 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000335017e7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003345512b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:35:55.581712 [ 2904 ] {63e11338-8a54-4419-bcb2-cf611a2983e8} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'x' in scope SELECT x, y, v, v.String, v.UInt64, v.Date FROM test ORDER BY x ASC. Maybe you meant: ['v']. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000335017e7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003345512b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:35:55.922949 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:35:56.480524 [ 9453 ] {b9e34d42-4f76-417f-9f70-b35a7f6daace} executeQuery: Code: 60. DB::Exception: Could not find table: comment_test_table. (UNKNOWN_TABLE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:55052) (comment: 02020_alter_table_modify_comment.sh) (in query: ALTER TABLE comment_test_table MODIFY COMMENT 'another comment on a 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000842350a 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034869c28 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003485e550 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 2025.10.23 23:35:56.482256 [ 9453 ] {b9e34d42-4f76-417f-9f70-b35a7f6daace} TCPHandler: Code: 60. DB::Exception: Could not find table: comment_test_table. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000842350a 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034869c28 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003485e550 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 2025.10.23 23:35:56.973729 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:35:57.064546 [ 2904 ] {f3c038eb-ee5d-4a55-a722-85f3594c2211} executeQuery: Code: 390. DB::Exception: Table `comment_test_table` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:55070) (comment: 02020_alter_table_modify_comment.sh) (in query: SHOW CREATE TABLE comment_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000032960fc6 5. ./src/Databases/IDatabase.h:0: DB::InterpreterShowCreateQuery::executeImpl() @ 0x00000000359e1aac 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x00000000359e0c24 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:35:57.067675 [ 2904 ] {f3c038eb-ee5d-4a55-a722-85f3594c2211} TCPHandler: Code: 390. DB::Exception: Table `comment_test_table` 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000032960fc6 5. ./src/Databases/IDatabase.h:0: DB::InterpreterShowCreateQuery::executeImpl() @ 0x00000000359e1aac 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x00000000359e0c24 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:35:57.085400 [ 7565 ] {4bb668b4-4a79-41f2-8d65-3b0095abf7aa} executeQuery: Code: 57. DB::Exception: Table test_11.t already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 00875_join_right_nulls_ors.sql) (in query: /* ddl_entry=query-0000000035 */ CREATE TABLE test_11.t UUID '32e8350f-9d7c-4bce-b1be-93ff2c4fc3ef' (`x` String) ENGINE = Log), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003395fc9e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000033958fac 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ad726d 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a52a3c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfab2 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:35:57.091533 [ 7565 ] {4bb668b4-4a79-41f2-8d65-3b0095abf7aa} executeQuery: Code: 57. DB::Exception: Table test_11.t already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:55010) (comment: 00875_join_right_nulls_ors.sql) (in query: CREATE TABLE t (x String) ENGINE = Log();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003395fc9e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000033958fac 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ad726d 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a52a3c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfab2 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:35:57.093710 [ 7565 ] {4bb668b4-4a79-41f2-8d65-3b0095abf7aa} TCPHandler: Code: 57. DB::Exception: Table test_11.t already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003395fc9e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000033958fac 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ad726d 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a52a3c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfab2 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:35:57.111505 [ 9434 ] {0893b2ca-017a-4cda-887c-2942009d13c0} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 62.103991174 seconds, maximum: 60. (TIMEOUT_EXCEEDED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44540) (comment: 02231_buffer_aggregate_states_leak.sql) (in query: insert into in_02231 select * from numbers(5e6) settings max_memory_usage='400Mi', max_threads=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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x00000000322cd7ed 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x00000000322cb868 5. ./build_docker/./src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000003502621c 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 8. ./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*) @ 0x000000003aea17d9 9. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 11. ? @ 0x00007f100c857ac3 12. ? @ 0x00007f100c8e9850 2025.10.23 23:35:57.664333 [ 9434 ] {0893b2ca-017a-4cda-887c-2942009d13c0} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 62.103991174 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x00000000322cd7ed 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x00000000322cb868 5. ./build_docker/./src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000003502621c 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 8. ./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*) @ 0x000000003aea17d9 9. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 11. ? @ 0x00007f100c857ac3 12. ? @ 0x00007f100c8e9850 2025.10.23 23:35:58.071838 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:35:58.166510 [ 2904 ] {0f46cfc0-f89c-41f2-b1a4-2662266a8517} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'x' in scope SELECT x, y, v, v.String, v.UInt64, v.Date FROM test ORDER BY x ASC. Maybe you meant: ['v']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:55100) (comment: 02941_variant_type_alters.sh) (in query: select x, y, v, v.String, v.UInt64, v.Date from test 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000335017e7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003345512b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:35:58.168763 [ 2904 ] {0f46cfc0-f89c-41f2-b1a4-2662266a8517} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'x' in scope SELECT x, y, v, v.String, v.UInt64, v.Date FROM test ORDER BY x ASC. Maybe you meant: ['v']. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000335017e7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003345512b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:35:58.901988 [ 9433 ] {227fcb23-c0d8-4cd9-a5d5-cfe631f18162} executeQuery: Code: 10. DB::Exception: Wrong column. Cannot find column `y` to modify. Maybe you meant: ['v']. (NOT_FOUND_COLUMN_IN_BLOCK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:55126) (comment: 02941_variant_type_alters.sh) (in query: alter table test modify column y Variant(UInt64, String) settings mutations_sync=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Storages/AlterCommands.cpp:1365: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000380b5d7b 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034866171 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003485e550 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:35:58.904828 [ 9433 ] {227fcb23-c0d8-4cd9-a5d5-cfe631f18162} TCPHandler: Code: 10. DB::Exception: Wrong column. Cannot find column `y` to modify. Maybe you meant: ['v']. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Storages/AlterCommands.cpp:1365: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000380b5d7b 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034866171 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003485e550 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:35:59.134238 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:35:59.818525 [ 9433 ] {ceac9102-f778-454e-a0f4-2049996496b3} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'x' in scope SELECT x, y, y.UInt64, y.String, v, v.String, v.UInt64, v.Date FROM test ORDER BY x ASC. Maybe you meant: ['v']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:55142) (comment: 02941_variant_type_alters.sh) (in query: select x, y, y.UInt64, y.String, v, v.String, v.UInt64, v.Date from test 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000335017e7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003345512b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:35:59.820484 [ 9433 ] {ceac9102-f778-454e-a0f4-2049996496b3} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'x' in scope SELECT x, y, y.UInt64, y.String, v, v.String, v.UInt64, v.Date FROM test ORDER BY x ASC. Maybe you meant: ['v']. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000335017e7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003345512b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:36:00.126729 [ 4752 ] {0d21bb36-e895-4da2-8d2a-ff8c518a0c94} executeQuery: Code: 60. DB::Exception: Table test_3hv5xr8k.comment_test_table does not exist. Maybe you meant test_15.enum_test_table?. (UNKNOWN_TABLE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:55120) (comment: 02020_alter_table_modify_comment.sh) (in query: DETACH TABLE comment_test_table 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x000000000861dc7f 4. ./build_docker/./src/Databases/IDatabase.cpp:39: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b146ec 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:433: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000003399fc33 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339b5107 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003493bddb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:36:00.129223 [ 4752 ] {0d21bb36-e895-4da2-8d2a-ff8c518a0c94} TCPHandler: Code: 60. DB::Exception: Table test_3hv5xr8k.comment_test_table does not exist. Maybe you meant test_15.enum_test_table?. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x000000000861dc7f 4. ./build_docker/./src/Databases/IDatabase.cpp:39: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b146ec 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:433: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000003399fc33 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339b5107 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003493bddb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:36:00.212438 [ 9433 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:00.611908 [ 2904 ] {c37dda17-aed5-4d72-bdb8-263c496f871f} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.000146854 seconds, maximum: 1. (TIMEOUT_EXCEEDED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:38526) (comment: 02786_max_execution_time_leaf.sql) (in query: SELECT count() AS `count()` FROM view(SELECT * FROM numbers(100000000000)) 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x00000000322cd7ed 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x00000000322cb868 5. ./build_docker/./src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000003502621c 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 9. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 11. ? @ 0x00007f100c857ac3 12. ? @ 0x00007f100c8e9850 2025.10.23 23:36:00.613834 [ 2904 ] {c37dda17-aed5-4d72-bdb8-263c496f871f} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.000146854 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x00000000322cd7ed 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x00000000322cb868 5. ./build_docker/./src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000003502621c 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 9. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 11. ? @ 0x00007f100c857ac3 12. ? @ 0x00007f100c8e9850 2025.10.23 23:36:00.701365 [ 9557 ] {c5885905-2749-48bc-b4b9-33077717d84c} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.011738147 seconds, maximum: 1. (TIMEOUT_EXCEEDED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:54048) (comment: 02786_max_execution_time_leaf.sql) (in query: SELECT count() AS `count()` FROM view(SELECT * FROM numbers(100000000000)) 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x00000000322cd7ed 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x00000000322cb868 5. ./build_docker/./src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000003502621c 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 9. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 11. ? @ 0x00007f100c857ac3 12. ? @ 0x00007f100c8e9850 2025.10.23 23:36:00.703248 [ 9557 ] {c5885905-2749-48bc-b4b9-33077717d84c} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.011738147 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x00000000322cd7ed 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x00000000322cb868 5. ./build_docker/./src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000003502621c 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 9. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 11. ? @ 0x00007f100c857ac3 12. ? @ 0x00007f100c8e9850 2025.10.23 23:36:00.754292 [ 9433 ] {0c22cd4e-e790-4a3b-b09f-8bceaff59eb4} executeQuery: Code: 390. DB::Exception: Table `comment_test_table` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:55180) (comment: 02020_alter_table_modify_comment.sh) (in query: SHOW CREATE TABLE comment_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000032960fc6 5. ./src/Databases/IDatabase.h:0: DB::InterpreterShowCreateQuery::executeImpl() @ 0x00000000359e1aac 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x00000000359e0c24 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:36:00.756094 [ 9433 ] {0c22cd4e-e790-4a3b-b09f-8bceaff59eb4} TCPHandler: Code: 390. DB::Exception: Table `comment_test_table` 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000032960fc6 5. ./src/Databases/IDatabase.h:0: DB::InterpreterShowCreateQuery::executeImpl() @ 0x00000000359e1aac 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x00000000359e0c24 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:36:01.365509 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:01.480625 [ 2904 ] {1620425f-677b-4f5a-9558-4229b5a97d53} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'x' in scope SELECT x, y, y.UInt64, y.String, v, v.String, v.UInt64, v.Date FROM test ORDER BY x ASC. Maybe you meant: ['v']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:55200) (comment: 02941_variant_type_alters.sh) (in query: select x, y, y.UInt64, y.String, v, v.String, v.UInt64, v.Date from test 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000335017e7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003345512b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:36:01.483919 [ 2904 ] {1620425f-677b-4f5a-9558-4229b5a97d53} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'x' in scope SELECT x, y, y.UInt64, y.String, v, v.String, v.UInt64, v.Date FROM test ORDER BY x ASC. Maybe you meant: ['v']. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000335017e7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003345512b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:36:01.620334 [ 9453 ] {68efd678-372c-41e7-9ea8-92e8f5f87fc5} executeQuery: Code: 159. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Timeout exceeded: elapsed 1.000146854 seconds, maximum: 1. Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x00000000322cd7ed 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x00000000322cb868 5. ./build_docker/./src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000003502621c 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 9. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 11. ? @ 0x00007f100c857ac3 12. ? @ 0x00007f100c8e9850 : While executing Remote. (TIMEOUT_EXCEEDED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:55112) (comment: 02786_max_execution_time_leaf.sql) (in query: SELECT count() FROM cluster('test_cluster_two_shards', view( SELECT * FROM numbers(100000000000) )) SETTINGS max_execution_time_leaf = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002019af32 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000003a7e3e0c 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::Connection::receivePacket() @ 0x000000003a7ff61b 5. ./build_docker/./src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003a8ed7f8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000323566d1 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032355a26 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000032352f12 2025.10.23 23:36:01.623565 [ 9453 ] {68efd678-372c-41e7-9ea8-92e8f5f87fc5} TCPHandler: Code: 159. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Timeout exceeded: elapsed 1.000146854 seconds, maximum: 1. Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x00000000322cd7ed 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x00000000322cb868 5. ./build_docker/./src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000003502621c 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 9. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 11. ? @ 0x00007f100c857ac3 12. ? @ 0x00007f100c8e9850 : While executing Remote. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002019af32 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000003a7e3e0c 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::Connection::receivePacket() @ 0x000000003a7ff61b 5. ./build_docker/./src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003a8ed7f8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000323566d1 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032355a26 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000032352f12 2025.10.23 23:36:02.418526 [ 9433 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:02.504653 [ 7565 ] {fcff1d54-cfa8-4b03-8bb6-6a497a597f78} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:55080) (comment: 00506_union_distributed.sql) (in query: select b, sum(c) from ( select a, b, sum(c) as c from union2 where a>1 group by a,b UNION ALL select a, b, sum(c) as c from union3 where b>1 group by a, b order by a, b) as a group by b order by b;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 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) @ 0x0000000039c89948 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000003999bfb7 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 @ 0x00000000399942f0 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039d45fb0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003bfd663a 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c083c53 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003bfe2b53 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d3c440 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf89b85 18. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 19. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 23. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 24. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 26. ? @ 0x00007f100c857ac3 27. ? @ 0x00007f100c8e9850 2025.10.23 23:36:02.522952 [ 7565 ] {fcff1d54-cfa8-4b03-8bb6-6a497a597f78} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 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) @ 0x0000000039c89948 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000003999bfb7 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 @ 0x00000000399942f0 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039d45fb0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003bfd663a 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c083c53 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003bfe2b53 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d3c440 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf89b85 18. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 19. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 23. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 24. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 26. ? @ 0x00007f100c857ac3 27. ? @ 0x00007f100c8e9850 2025.10.23 23:36:03.022269 [ 9557 ] {3692066b-048d-4279-8137-374e978c35c8} executeQuery: Code: 390. DB::Exception: Table `comment_test_table` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:55208) (comment: 02020_alter_table_modify_comment.sh) (in query: ATTACH TABLE comment_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000032960fc6 5. ./src/Databases/IDatabase.h:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c9c7c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:36:03.025318 [ 9557 ] {3692066b-048d-4279-8137-374e978c35c8} TCPHandler: Code: 390. DB::Exception: Table `comment_test_table` 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000032960fc6 5. ./src/Databases/IDatabase.h:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348c9c7c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:36:03.474045 [ 9433 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:03.649849 [ 9433 ] {5835c929-9165-49fb-b551-824536e20d03} executeQuery: Code: 390. DB::Exception: Table `comment_test_table` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:55284) (comment: 02020_alter_table_modify_comment.sh) (in query: SHOW CREATE TABLE comment_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000032960fc6 5. ./src/Databases/IDatabase.h:0: DB::InterpreterShowCreateQuery::executeImpl() @ 0x00000000359e1aac 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x00000000359e0c24 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:36:03.697132 [ 9433 ] {5835c929-9165-49fb-b551-824536e20d03} TCPHandler: Code: 390. DB::Exception: Table `comment_test_table` 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000032960fc6 5. ./src/Databases/IDatabase.h:0: DB::InterpreterShowCreateQuery::executeImpl() @ 0x00000000359e1aac 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x00000000359e0c24 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:36:04.260259 [ 9453 ] {a931c662-b8ce-4ef7-a59e-05e4923cd80e} executeQuery: Code: 392. DB::Exception: Cannot execute query. DDL queries are prohibited for the user default. (QUERY_IS_PROHIBITED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:55248) (comment: 00716_allow_ddl.sql) (in query: CREATE DATABASE some_db;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: auto bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000312de4fb 4. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const @ 0x00000000312db513 5. ./build_docker/./src/Access/ContextAccess.cpp:778: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessRightsElement const&) const @ 0x00000000312f17b3 6. ./build_docker/./src/Access/ContextAccess.cpp:0: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessRightsElements const&) const @ 0x0000000031296fcd 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessRightsElements const&) const @ 0x000000003373675b 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6ce2 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:04.261347 [ 9453 ] {a931c662-b8ce-4ef7-a59e-05e4923cd80e} TCPHandler: Code: 392. DB::Exception: Cannot execute query. DDL queries are prohibited for the user default. (QUERY_IS_PROHIBITED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: auto bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000312de4fb 4. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const @ 0x00000000312db513 5. ./build_docker/./src/Access/ContextAccess.cpp:778: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessRightsElement const&) const @ 0x00000000312f17b3 6. ./build_docker/./src/Access/ContextAccess.cpp:0: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessRightsElements const&) const @ 0x0000000031296fcd 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessRightsElements const&) const @ 0x000000003373675b 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6ce2 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:04.523096 [ 3895 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:05.203197 [ 9453 ] {ce907429-0873-4a80-891d-875a5ddd00cd} executeQuery: Code: 392. DB::Exception: Cannot execute query. DDL queries are prohibited for the user default. (QUERY_IS_PROHIBITED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:55248) (comment: 00716_allow_ddl.sql) (in query: CREATE TABLE some_table(a Int32) ENGINE = Memory;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: auto bool DB::ContextAccess::checkAccessImplHelper>, String>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, String const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000031300918 4. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>, String>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, String const&) const @ 0x00000000312fd40f 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessRightsElement const&) const @ 0x00000000312f19da 6. ./build_docker/./src/Access/ContextAccess.cpp:0: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessRightsElements const&) const @ 0x0000000031296fcd 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessRightsElements const&) const @ 0x000000003373675b 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6ce2 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:05.204438 [ 9453 ] {ce907429-0873-4a80-891d-875a5ddd00cd} TCPHandler: Code: 392. DB::Exception: Cannot execute query. DDL queries are prohibited for the user default. (QUERY_IS_PROHIBITED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: auto bool DB::ContextAccess::checkAccessImplHelper>, String>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, String const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000031300918 4. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>, String>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, String const&) const @ 0x00000000312fd40f 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessRightsElement const&) const @ 0x00000000312f19da 6. ./build_docker/./src/Access/ContextAccess.cpp:0: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessRightsElements const&) const @ 0x0000000031296fcd 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessRightsElements const&) const @ 0x000000003373675b 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6ce2 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:05.567637 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:06.454725 [ 9453 ] {99be9709-c78b-4c34-96f6-994719cb9c44} executeQuery: Code: 392. DB::Exception: Cannot execute query. DDL queries are prohibited for the user default. (QUERY_IS_PROHIBITED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:55248) (comment: 00716_allow_ddl.sql) (in query: ALTER TABLE some_table DELETE 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: auto bool DB::ContextAccess::checkAccessImplHelper>, String>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, String const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000031300918 4. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>, String>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, String const&) const @ 0x00000000312fd40f 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessRightsElement const&) const @ 0x00000000312f19da 6. ./build_docker/./src/Access/ContextAccess.cpp:0: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessRightsElements const&) const @ 0x0000000031296fcd 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessRightsElements const&) const @ 0x000000003373675b 8. ./contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003486108a 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003485e550 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:36:06.456083 [ 9453 ] {99be9709-c78b-4c34-96f6-994719cb9c44} TCPHandler: Code: 392. DB::Exception: Cannot execute query. DDL queries are prohibited for the user default. (QUERY_IS_PROHIBITED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: auto bool DB::ContextAccess::checkAccessImplHelper>, String>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, String const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000031300918 4. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>, String>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, String const&) const @ 0x00000000312fd40f 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessRightsElement const&) const @ 0x00000000312f19da 6. ./build_docker/./src/Access/ContextAccess.cpp:0: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessRightsElements const&) const @ 0x0000000031296fcd 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessRightsElements const&) const @ 0x000000003373675b 8. ./contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003486108a 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003485e550 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:36:06.660887 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:07.470412 [ 9453 ] {d8ab007a-aedc-475f-8539-8200f22b55ca} executeQuery: Code: 392. DB::Exception: Cannot execute query. DDL queries are prohibited for the user default. (QUERY_IS_PROHIBITED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:55248) (comment: 00716_allow_ddl.sql) (in query: RENAME TABLE some_table TO some_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: auto bool DB::ContextAccess::checkAccessImplHelper>, String>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, String const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000031300918 4. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>, String>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, String const&) const @ 0x00000000312fd40f 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessRightsElement const&) const @ 0x00000000312f19da 6. ./build_docker/./src/Access/ContextAccess.cpp:0: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessRightsElements const&) const @ 0x0000000031296fcd 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessRightsElements const&) const @ 0x000000003373675b 8. ./contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterRenameQuery::execute() @ 0x0000000034bd1838 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:07.471526 [ 9453 ] {d8ab007a-aedc-475f-8539-8200f22b55ca} TCPHandler: Code: 392. DB::Exception: Cannot execute query. DDL queries are prohibited for the user default. (QUERY_IS_PROHIBITED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: auto bool DB::ContextAccess::checkAccessImplHelper>, String>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, String const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000031300918 4. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>, String>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, String const&) const @ 0x00000000312fd40f 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessRightsElement const&) const @ 0x00000000312f19da 6. ./build_docker/./src/Access/ContextAccess.cpp:0: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessRightsElements const&) const @ 0x0000000031296fcd 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessRightsElements const&) const @ 0x000000003373675b 8. ./contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterRenameQuery::execute() @ 0x0000000034bd1838 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:07.786141 [ 3895 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:08.387273 [ 3895 ] {302440f8-84eb-4696-a2aa-521a4c0b75ea} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:39626) (comment: 02377_extend_protocol_with_query_parameters.sh) (in query: CREATE TABLE t_02377_extend_protocol_with_query_parameters_163074261 (`id` Int64, `arr` Array(UInt8), `map` Map(String, UInt8), `mul_arr` Array(Array(UInt8)), `map_arr` Map(UInt8, Array(UInt8)), `map_map_arr` Map(String, Map(String, Array(UInt8)))) ENGINE = MergeTree ORDER BY id SETTINGS index_granularity = 38836, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 150332186, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 21603196, merge_max_block_size = 9644, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 8247082051, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 17941316, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 45380, primary_key_compress_block_size = 74155), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x0000000039709f85 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>) @ 0x000000003a2e5f4a 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a2e404f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2d3063 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7b27a 12. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x0000000038308626 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348e414c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:36:08.389471 [ 3895 ] {302440f8-84eb-4696-a2aa-521a4c0b75ea} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x0000000039709f85 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>) @ 0x000000003a2e5f4a 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a2e404f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2d3063 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7b27a 12. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x0000000038308626 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348e414c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:36:08.634160 [ 9453 ] {d659896f-7410-40ad-8eff-dd6909f6302b} executeQuery: Code: 392. DB::Exception: Cannot modify 'allow_ddl' setting when DDL queries are prohibited for the user. (QUERY_IS_PROHIBITED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:55248) (comment: 00716_allow_ddl.sql) (in query: SET allow_ddl = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: DB::Exception::Exception(PreformattedMessage const&, int) @ 0x000000002fde43dd 3. ./build_docker/./src/Access/SettingsConstraints.cpp:307: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c447 4. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 5. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000003159b57b 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337550f2 7. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e79fb4 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:36:08.635106 [ 9453 ] {d659896f-7410-40ad-8eff-dd6909f6302b} TCPHandler: Code: 392. DB::Exception: Cannot modify 'allow_ddl' setting when DDL queries are prohibited for the user. (QUERY_IS_PROHIBITED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: DB::Exception::Exception(PreformattedMessage const&, int) @ 0x000000002fde43dd 3. ./build_docker/./src/Access/SettingsConstraints.cpp:307: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c447 4. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 5. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000003159b57b 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337550f2 7. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e79fb4 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:36:08.890866 [ 7759 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:09.121432 [ 7759 ] {8979cace-efe2-4a67-acab-26c1dfe0361f} executeQuery: Code: 60. DB::Exception: Table test_vi9drm2x.t_02377_extend_protocol_with_query_parameters_163074261 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:39666) (comment: 02377_extend_protocol_with_query_parameters.sh) (in query: insert into t_02377_extend_protocol_with_query_parameters_163074261 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b14381 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:433: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000003399fc33 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:957: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339b4ac1 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000034b9ec4f 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000034bb99c8 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:09.123157 [ 7759 ] {8979cace-efe2-4a67-acab-26c1dfe0361f} TCPHandler: Code: 60. DB::Exception: Table test_vi9drm2x.t_02377_extend_protocol_with_query_parameters_163074261 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b14381 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:433: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000003399fc33 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:957: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339b4ac1 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000034b9ec4f 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000034bb99c8 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:09.807323 [ 4841 ] {049ae236-8d05-4aa9-9537-c33ab792c217} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't_02377_extend_protocol_with_query_parameters_163074261' in scope SELECT * FROM t_02377_extend_protocol_with_query_parameters_163074261. (UNKNOWN_TABLE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:39670) (comment: 02377_extend_protocol_with_query_parameters.sh) (in query: select * from t_02377_extend_protocol_with_query_parameters_163074261), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa0996d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334eae8a 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003343676d 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 2025.10.23 23:36:09.809564 [ 4841 ] {049ae236-8d05-4aa9-9537-c33ab792c217} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't_02377_extend_protocol_with_query_parameters_163074261' in scope SELECT * FROM t_02377_extend_protocol_with_query_parameters_163074261. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa0996d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334eae8a 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003343676d 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 2025.10.23 23:36:09.880955 [ 3933 ] {eb607cf3-fe20-4772-92aa-08cfad3ea9db} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:35658) (comment: 02941_variant_type_alters.sh) (in query: SELECT `__table1`.`x` AS `x`, `__table1`.`y` AS `y`, `__table1`.`v` AS `v`, `__table1`.`v.String` AS `v.String`, `__table1`.`v.UInt64` AS `v.UInt64` FROM `test_15`.`test` AS `__table1` ORDER BY `__table1`.`x` 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202dea34 6. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039a5dbc5 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003bf2b229 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bf26bba 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003bf26345 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bf3d5b9 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2045: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf42fe0 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be48783 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003beb6da5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034cf5e6d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034cf5881 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:36:09.883169 [ 3933 ] {eb607cf3-fe20-4772-92aa-08cfad3ea9db} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202dea34 6. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039a5dbc5 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003bf2b229 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bf26bba 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003bf26345 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bf3d5b9 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2045: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf42fe0 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be48783 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003beb6da5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034cf5e6d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034cf5881 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:36:09.951564 [ 7759 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:10.990683 [ 7759 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:11.234513 [ 6965 ] {650a4d9a-7957-415b-90fd-9df767eb63aa} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:60320) (comment: 02941_variant_type_alters.sh) (in query: SELECT `__table1`.`x` AS `x`, `__table1`.`y` AS `y`, `__table1`.`v` AS `v`, `__table1`.`v.String` AS `v.String`, `__table1`.`v.UInt64` AS `v.UInt64` FROM `test_15`.`test` AS `__table1` ORDER BY `__table1`.`x` 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202dea34 6. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039a5dbc5 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003bf2b229 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bf26bba 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003bf26345 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bf3d5b9 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2045: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf42fe0 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be48783 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003beb6da5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034cf5e6d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034cf5881 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:36:11.236493 [ 6965 ] {650a4d9a-7957-415b-90fd-9df767eb63aa} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202dea34 6. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039a5dbc5 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003bf2b229 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bf26bba 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003bf26345 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bf3d5b9 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2045: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf42fe0 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be48783 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003beb6da5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034cf5e6d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034cf5881 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:36:11.238955 [ 3895 ] {3544a986-f312-4bb9-9f63-0b760e3bfce4} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.10:9000. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202dea34 6. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039a5dbc5 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003bf2b229 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bf26bba 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003bf26345 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bf3d5b9 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2045: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf42fe0 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be48783 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003beb6da5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034cf5e6d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034cf5881 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:39686) (comment: 02941_variant_type_alters.sh) (in query: select x, y, v, v.String, v.UInt64 from test 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002019af32 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000003a7e3e0c 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::Connection::receivePacket() @ 0x000000003a7ff61b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:340: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003a8df9b9 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:0: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000032358b71 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000323566d1 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032355a26 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000032352f12 2025.10.23 23:36:11.316631 [ 3903 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:47302, 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x00000000204bfd30 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x00000000204c0cc1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a8112cd 6. DB::ReadBuffer::next() @ 0x00000000095b468f 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000003abd729e 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:11.318216 [ 6965 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:60320, local: [::ffff:127.0.0.7]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x00000000204bfd30 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x00000000204c0cc1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a8112cd 6. DB::ReadBuffer::next() @ 0x00000000095b468f 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000003abd729e 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:11.319625 [ 3895 ] {3544a986-f312-4bb9-9f63-0b760e3bfce4} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.10:9000. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202dea34 6. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039a5dbc5 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003bf2b229 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bf26bba 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003bf26345 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bf3d5b9 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2045: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf42fe0 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be48783 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003beb6da5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034cf5e6d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034cf5881 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 : 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002019af32 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000003a7e3e0c 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::Connection::receivePacket() @ 0x000000003a7ff61b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:340: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003a8df9b9 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:0: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000032358b71 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000323566d1 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032355a26 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000032352f12 2025.10.23 23:36:12.068990 [ 4745 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:13.154749 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:13.569316 [ 3895 ] {76887ae8-a1de-4aae-a63d-566a82d3cefc} executeQuery: Code: 456. DB::Exception: Substitution `n` is not set. (UNKNOWN_QUERY_PARAMETER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:39794) (comment: 02377_extend_protocol_with_query_parameters.sh) (in query: select {n: UInt8} -- { serverError 456 }), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:70: DB::ReplaceQueryParameterVisitor::getParamValue(String const&) @ 0x0000000035855c2b 5. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:0: DB::ReplaceQueryParameterVisitor::visitQueryParameter(std::shared_ptr&) @ 0x0000000035851bff 6. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:0: DB::ReplaceQueryParameterVisitor::visit(std::shared_ptr&) @ 0x0000000035851816 7. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:0: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000358555d2 8. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:48: DB::ReplaceQueryParameterVisitor::visit(std::shared_ptr&) @ 0x0000000035851a17 9. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:0: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000358555d2 10. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:48: DB::ReplaceQueryParameterVisitor::visit(std::shared_ptr&) @ 0x0000000035851a17 11. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:0: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000358555d2 12. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:48: DB::ReplaceQueryParameterVisitor::visit(std::shared_ptr&) @ 0x0000000035851a17 13. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:0: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000358555d2 14. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:48: DB::ReplaceQueryParameterVisitor::visit(std::shared_ptr&) @ 0x0000000035851a17 15. ./src/Interpreters/ReplaceQueryParameterVisitor.h:23: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358ae427 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:36:13.570270 [ 3895 ] {76887ae8-a1de-4aae-a63d-566a82d3cefc} TCPHandler: Code: 456. DB::Exception: Substitution `n` is not set. (UNKNOWN_QUERY_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:70: DB::ReplaceQueryParameterVisitor::getParamValue(String const&) @ 0x0000000035855c2b 5. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:0: DB::ReplaceQueryParameterVisitor::visitQueryParameter(std::shared_ptr&) @ 0x0000000035851bff 6. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:0: DB::ReplaceQueryParameterVisitor::visit(std::shared_ptr&) @ 0x0000000035851816 7. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:0: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000358555d2 8. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:48: DB::ReplaceQueryParameterVisitor::visit(std::shared_ptr&) @ 0x0000000035851a17 9. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:0: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000358555d2 10. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:48: DB::ReplaceQueryParameterVisitor::visit(std::shared_ptr&) @ 0x0000000035851a17 11. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:0: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000358555d2 12. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:48: DB::ReplaceQueryParameterVisitor::visit(std::shared_ptr&) @ 0x0000000035851a17 13. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:0: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000358555d2 14. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:48: DB::ReplaceQueryParameterVisitor::visit(std::shared_ptr&) @ 0x0000000035851a17 15. ./src/Interpreters/ReplaceQueryParameterVisitor.h:23: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358ae427 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:36:14.270365 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:14.517156 [ 4799 ] {8677fea9-b53b-4ec0-a2be-ddae9a1b3e40} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, jobs=1): (while reading column v): (while reading from part /var/lib/clickhouse/store/6a9/6a9dd6b3-bc67-4638-b78e-461dda2d048a/all_5_5_0_6/ in table test_15.test (6a9dd6b3-bc67-4638-b78e-461dda2d048a) located on disk default of type local, from mark 0 with max_rows_to_read = 3): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:55012) (comment: 02941_variant_type_alters.sh) (in query: SELECT `__table1`.`x` AS `x`, `__table1`.`y` AS `y`, `__table1`.`v` AS `v`, `__table1`.`v.String` AS `v.String`, `__table1`.`v.UInt64` AS `v.UInt64`, `__table1`.`v.Date` AS `v.Date` FROM `test_15`.`test` AS `__table1` ORDER BY `__table1`.`x` 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000003075641a 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030755c60 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000307521d1 9. ./src/IO/AsynchronousReader.h:48: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000003073084e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000003073196f 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:163: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x00000000320e5233 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:22: DB::CompressedReadBufferFromFile::nextImpl() @ 0x00000000320eb1b7 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::nextImpl() @ 0x00000000320eb74d 15. DB::ReadBuffer::next() @ 0x00000000095b468f 16. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:168: DB::MergeTreeMarksLoader::loadMarksImpl() @ 0x0000000039c0e588 17. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:216: DB::MergeTreeMarksLoader::loadMarksSync() @ 0x0000000039c0a34d 18. ./src/Common/threadPoolCallbackRunner.h:0: std::__packaged_task_func> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)::operator()(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)::'lambda'(), std::allocator> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)::operator()(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)::'lambda'()>, std::shared_ptr ()>::operator()() @ 0x0000000039c12b04 19. ./contrib/llvm-project/libcxx/include/future:1953: std::packaged_task ()>::operator()() @ 0x0000000039c1a8c2 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039c12e0e 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 24. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 26. ? @ 0x00007f100c857ac3 27. ? @ 0x00007f100c8e9850 2025.10.23 23:36:14.522750 [ 4799 ] {8677fea9-b53b-4ec0-a2be-ddae9a1b3e40} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, jobs=1): (while reading column v): (while reading from part /var/lib/clickhouse/store/6a9/6a9dd6b3-bc67-4638-b78e-461dda2d048a/all_5_5_0_6/ in table test_15.test (6a9dd6b3-bc67-4638-b78e-461dda2d048a) located on disk default of type local, from mark 0 with max_rows_to_read = 3): 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000003075641a 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030755c60 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000307521d1 9. ./src/IO/AsynchronousReader.h:48: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000003073084e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000003073196f 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:163: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x00000000320e5233 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:22: DB::CompressedReadBufferFromFile::nextImpl() @ 0x00000000320eb1b7 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::nextImpl() @ 0x00000000320eb74d 15. DB::ReadBuffer::next() @ 0x00000000095b468f 16. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:168: DB::MergeTreeMarksLoader::loadMarksImpl() @ 0x0000000039c0e588 17. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:216: DB::MergeTreeMarksLoader::loadMarksSync() @ 0x0000000039c0a34d 18. ./src/Common/threadPoolCallbackRunner.h:0: std::__packaged_task_func> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)::operator()(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)::'lambda'(), std::allocator> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)::operator()(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)::'lambda'()>, std::shared_ptr ()>::operator()() @ 0x0000000039c12b04 19. ./contrib/llvm-project/libcxx/include/future:1953: std::packaged_task ()>::operator()() @ 0x0000000039c1a8c2 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039c12e0e 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 24. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 26. ? @ 0x00007f100c857ac3 27. ? @ 0x00007f100c8e9850 2025.10.23 23:36:14.529471 [ 4745 ] {d25649c2-531b-4817-924a-144468b7f58f} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.5:9000. DB::Exception: Cannot schedule a task: fault injected (threads=15, jobs=1): (while reading column v): (while reading from part /var/lib/clickhouse/store/6a9/6a9dd6b3-bc67-4638-b78e-461dda2d048a/all_5_5_0_6/ in table test_15.test (6a9dd6b3-bc67-4638-b78e-461dda2d048a) located on disk default of type local, from mark 0 with max_rows_to_read = 3): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000003075641a 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030755c60 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000307521d1 9. ./src/IO/AsynchronousReader.h:48: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000003073084e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000003073196f 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:163: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x00000000320e5233 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:22: DB::CompressedReadBufferFromFile::nextImpl() @ 0x00000000320eb1b7 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::nextImpl() @ 0x00000000320eb74d 15. DB::ReadBuffer::next() @ 0x00000000095b468f 16. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:168: DB::MergeTreeMarksLoader::loadMarksImpl() @ 0x0000000039c0e588 17. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:216: DB::MergeTreeMarksLoader::loadMarksSync() @ 0x0000000039c0a34d 18. ./src/Common/threadPoolCallbackRunner.h:0: std::__packaged_task_func> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)::operator()(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)::'lambda'(), std::allocator> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)::operator()(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)::'lambda'()>, std::shared_ptr ()>::operator()() @ 0x0000000039c12b04 19. ./contrib/llvm-project/libcxx/include/future:1953: std::packaged_task ()>::operator()() @ 0x0000000039c1a8c2 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039c12e0e 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 24. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 26. ? @ 0x00007f100c857ac3 27. ? @ 0x00007f100c8e9850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:39818) (comment: 02941_variant_type_alters.sh) (in query: select x, y, v, v.String, v.UInt64, v.Date from test 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002019af32 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000003a7e3e0c 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::Connection::receivePacket() @ 0x000000003a7ff61b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:340: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003a8df9b9 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:0: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000032358b71 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000323566d1 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032355a26 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000032352f12 2025.10.23 23:36:14.535311 [ 4745 ] {d25649c2-531b-4817-924a-144468b7f58f} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.5:9000. DB::Exception: Cannot schedule a task: fault injected (threads=15, jobs=1): (while reading column v): (while reading from part /var/lib/clickhouse/store/6a9/6a9dd6b3-bc67-4638-b78e-461dda2d048a/all_5_5_0_6/ in table test_15.test (6a9dd6b3-bc67-4638-b78e-461dda2d048a) located on disk default of type local, from mark 0 with max_rows_to_read = 3): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000003075641a 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030755c60 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000307521d1 9. ./src/IO/AsynchronousReader.h:48: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000003073084e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000003073196f 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:163: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x00000000320e5233 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:22: DB::CompressedReadBufferFromFile::nextImpl() @ 0x00000000320eb1b7 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::nextImpl() @ 0x00000000320eb74d 15. DB::ReadBuffer::next() @ 0x00000000095b468f 16. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:168: DB::MergeTreeMarksLoader::loadMarksImpl() @ 0x0000000039c0e588 17. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:216: DB::MergeTreeMarksLoader::loadMarksSync() @ 0x0000000039c0a34d 18. ./src/Common/threadPoolCallbackRunner.h:0: std::__packaged_task_func> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)::operator()(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)::'lambda'(), std::allocator> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)::operator()(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)::'lambda'()>, std::shared_ptr ()>::operator()() @ 0x0000000039c12b04 19. ./contrib/llvm-project/libcxx/include/future:1953: std::packaged_task ()>::operator()() @ 0x0000000039c1a8c2 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039c12e0e 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 24. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 26. ? @ 0x00007f100c857ac3 27. ? @ 0x00007f100c8e9850 : 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002019af32 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000003a7e3e0c 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::Connection::receivePacket() @ 0x000000003a7ff61b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:340: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003a8df9b9 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:0: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000032358b71 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000323566d1 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032355a26 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000032352f12 2025.10.23 23:36:14.608793 [ 4841 ] {72add528-247c-4853-a068-c2c5cef4bc7d} executeQuery: Code: 70. DB::Exception: Cannot convert NULL to a non-nullable type: while converting source column src to destination column val. (CANNOT_CONVERT_TYPE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:39830) (comment: 00690_insert_select_converting_exception_message.sh) (in query: INSERT INTO test_00690 SELECT NULL AS src SETTINGS insert_null_as_default=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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. DB::(anonymous namespace)::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x00000000086d054f 5. DB::(anonymous namespace)::FunctionCast::prepare(std::vector> const&) const @ 0x00000000086c8c11 6. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x0000000033226b27 7. ./build_docker/./src/Interpreters/ActionsDAG.cpp:286: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x0000000033229f1d 8. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x00000000332710ae 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034bb0883 10. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034bbac4c 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:36:14.609767 [ 4841 ] {72add528-247c-4853-a068-c2c5cef4bc7d} TCPHandler: Code: 70. DB::Exception: Cannot convert NULL to a non-nullable type: while converting source column src to destination column val. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. DB::(anonymous namespace)::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x00000000086d054f 5. DB::(anonymous namespace)::FunctionCast::prepare(std::vector> const&) const @ 0x00000000086c8c11 6. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x0000000033226b27 7. ./build_docker/./src/Interpreters/ActionsDAG.cpp:286: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x0000000033229f1d 8. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x00000000332710ae 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034bb0883 10. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034bbac4c 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:36:15.321729 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:16.375953 [ 3895 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:16.591404 [ 3645 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {d60c8165-1f8c-4cd1-8084-8b8c63363ea3::202510_1_47_9}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 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) @ 0x0000000039c89948 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000003999bfb7 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 @ 0x00000000399942f0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000039d15c04 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&) @ 0x0000000039d20399 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) @ 0x0000000039d1c606 15. ./contrib/llvm-project/libcxx/include/optional:260: DB::MergeTask::VerticalMergeStage::createPipeForReadingOneColumn(String const&) const @ 0x000000003963fa21 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::prepareVerticalMergeForOneColumn() const @ 0x0000000039641691 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::executeVerticalMergeForAllColumns() const @ 0x00000000396522a9 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1004: DB::MergeTask::VerticalMergeStage::execute() @ 0x0000000039651c40 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x00000000396504a0 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3c455d 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:17.041171 [ 4745 ] {11c31bdd-b7bb-4ddc-8292-8617b1fdf204} executeQuery: Code: 349. DB::Exception: Cannot convert NULL value to non-Nullable type: while converting source column src to destination column val: while executing 'FUNCTION _CAST(src :: 0, Int64 :: 1) -> _CAST(src, Int64) Int64 : 2'. (CANNOT_INSERT_NULL_IN_ORDINARY_COLUMN) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:39150) (comment: 00690_insert_select_converting_exception_message.sh) (in query: INSERT INTO test_00690 SELECT number % 2 ? 1 : NULL AS src FROM numbers(10) SETTINGS insert_null_as_default=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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 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) @ 0x00000000091c4b52 5. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086d2b34 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffeaa 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601e5f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a24ade 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b82c484 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acdc84 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae66ecb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 17. ./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*) @ 0x000000003aea17d9 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:36:17.043129 [ 4745 ] {11c31bdd-b7bb-4ddc-8292-8617b1fdf204} TCPHandler: Code: 349. DB::Exception: Cannot convert NULL value to non-Nullable type: while converting source column src to destination column val: while executing 'FUNCTION _CAST(src :: 0, Int64 :: 1) -> _CAST(src, Int64) Int64 : 2'. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 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) @ 0x00000000091c4b52 5. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086d2b34 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffeaa 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601e5f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a24ade 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b82c484 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acdc84 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae66ecb 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 17. ./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*) @ 0x000000003aea17d9 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:36:17.534237 [ 4745 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:18.213509 [ 3655 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {d60c8165-1f8c-4cd1-8084-8b8c63363ea3::202510_1_47_9}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 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) @ 0x0000000039c89948 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000003999bfb7 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 @ 0x00000000399942f0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000039d15c04 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&) @ 0x0000000039d20399 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) @ 0x0000000039d1c606 15. ./contrib/llvm-project/libcxx/include/optional:260: DB::MergeTask::VerticalMergeStage::createPipeForReadingOneColumn(String const&) const @ 0x000000003963fa21 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::prepareVerticalMergeForOneColumn() const @ 0x0000000039641691 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::executeVerticalMergeForAllColumns() const @ 0x00000000396522a9 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1004: DB::MergeTask::VerticalMergeStage::execute() @ 0x0000000039651c40 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x00000000396504a0 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3c455d 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:18.603863 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:19.666733 [ 3894 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:20.830258 [ 3657 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {d60c8165-1f8c-4cd1-8084-8b8c63363ea3::202510_1_47_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 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) @ 0x0000000039c89948 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000003999bfb7 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 @ 0x00000000399942f0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000039d15c04 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&) @ 0x0000000039d20399 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) @ 0x0000000039d1c606 15. ./contrib/llvm-project/libcxx/include/optional:260: DB::MergeTask::VerticalMergeStage::createPipeForReadingOneColumn(String const&) const @ 0x000000003963fa21 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::prepareVerticalMergeForOneColumn() const @ 0x0000000039641691 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::executeVerticalMergeForAllColumns() const @ 0x00000000396522a9 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1004: DB::MergeTask::VerticalMergeStage::execute() @ 0x0000000039651c40 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x00000000396504a0 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3c455d 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:20.848172 [ 3895 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:21.597708 [ 4649 ] {9156a388-6a71-43bf-8e1c-2a198d8240af} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, jobs=1): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:35430) (comment: 02941_variant_type_alters.sh) (in query: SELECT `__table1`.`x` AS `x`, `__table1`.`y` AS `y`, `__table1`.`y.UInt64` AS `y.UInt64`, `__table1`.`y.String` AS `y.String`, `__table1`.`v` AS `v`, `__table1`.`v.String` AS `v.String`, `__table1`.`v.UInt64` AS `v.UInt64`, `__table1`.`v.Date` AS `v.Date` FROM `test_15`.`test` AS `__table1` ORDER BY `__table1`.`x` 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000039d07892 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&) @ 0x0000000039d09d4a 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:63: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x00000000326402a2 12. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:0: DB::SerializationSparse::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000003282ef45 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000032640cad 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000039d01224 15. ./contrib/llvm-project/libcxx/include/vector:547: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000039d00b49 16. ./contrib/llvm-project/libcxx/include/__tree:1088: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) @ 0x00000000399bb1c8 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 @ 0x00000000399b0254 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039d45fb0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003bfd663a 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolParallelReplicas.cpp:201: DB::MergeTreeReadPoolParallelReplicas::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c062f6e 21. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:37: DB::MergeTreeThreadSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003bf806f4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d3c440 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf89b85 24. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 25. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 29. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 31. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 2025.10.23 23:36:21.601990 [ 4649 ] {9156a388-6a71-43bf-8e1c-2a198d8240af} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, jobs=1): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000039d07892 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&) @ 0x0000000039d09d4a 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:63: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x00000000326402a2 12. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:0: DB::SerializationSparse::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000003282ef45 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000032640cad 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000039d01224 15. ./contrib/llvm-project/libcxx/include/vector:547: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000039d00b49 16. ./contrib/llvm-project/libcxx/include/__tree:1088: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) @ 0x00000000399bb1c8 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 @ 0x00000000399b0254 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039d45fb0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003bfd663a 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolParallelReplicas.cpp:201: DB::MergeTreeReadPoolParallelReplicas::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c062f6e 21. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:37: DB::MergeTreeThreadSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003bf806f4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d3c440 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf89b85 24. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 25. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 29. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 31. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 2025.10.23 23:36:21.606199 [ 4841 ] {ea5a6c3b-6e43-4c61-b75d-6d1c983a4108} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.4:9000. DB::Exception: Cannot schedule a task: fault injected (threads=15, jobs=1): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000039d07892 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&) @ 0x0000000039d09d4a 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:63: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x00000000326402a2 12. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:0: DB::SerializationSparse::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000003282ef45 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000032640cad 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000039d01224 15. ./contrib/llvm-project/libcxx/include/vector:547: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000039d00b49 16. ./contrib/llvm-project/libcxx/include/__tree:1088: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) @ 0x00000000399bb1c8 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 @ 0x00000000399b0254 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039d45fb0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003bfd663a 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolParallelReplicas.cpp:201: DB::MergeTreeReadPoolParallelReplicas::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c062f6e 21. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:37: DB::MergeTreeThreadSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003bf806f4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d3c440 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf89b85 24. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 25. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 29. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 31. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:39282) (comment: 02941_variant_type_alters.sh) (in query: select x, y, y.UInt64, y.String, v, v.String, v.UInt64, v.Date from test 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002019af32 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000003a7e3e0c 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::Connection::receivePacket() @ 0x000000003a7ff61b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:340: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003a8df9b9 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:0: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000032358b71 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000323566d1 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032355a26 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000032352f12 2025.10.23 23:36:21.609594 [ 4841 ] {ea5a6c3b-6e43-4c61-b75d-6d1c983a4108} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.4:9000. DB::Exception: Cannot schedule a task: fault injected (threads=15, jobs=1): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000039d07892 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&) @ 0x0000000039d09d4a 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:63: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x00000000326402a2 12. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:0: DB::SerializationSparse::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000003282ef45 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000032640cad 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000039d01224 15. ./contrib/llvm-project/libcxx/include/vector:547: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000039d00b49 16. ./contrib/llvm-project/libcxx/include/__tree:1088: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) @ 0x00000000399bb1c8 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 @ 0x00000000399b0254 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039d45fb0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003bfd663a 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolParallelReplicas.cpp:201: DB::MergeTreeReadPoolParallelReplicas::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c062f6e 21. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:37: DB::MergeTreeThreadSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003bf806f4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d3c440 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf89b85 24. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 25. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 29. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 31. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd : 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002019af32 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000003a7e3e0c 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::Connection::receivePacket() @ 0x000000003a7ff61b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:340: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003a8df9b9 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:0: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000032358b71 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000323566d1 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032355a26 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000032352f12 2025.10.23 23:36:21.907891 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:22.152294 [ 3652 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {d60c8165-1f8c-4cd1-8084-8b8c63363ea3::202510_1_47_9}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 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) @ 0x0000000039c89948 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000003999bfb7 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 @ 0x00000000399942f0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000039d15c04 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&) @ 0x0000000039d20399 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) @ 0x0000000039d1c606 15. ./contrib/llvm-project/libcxx/include/optional:260: DB::MergeTask::VerticalMergeStage::createPipeForReadingOneColumn(String const&) const @ 0x000000003963fa21 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::prepareVerticalMergeForOneColumn() const @ 0x0000000039641691 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::executeVerticalMergeForAllColumns() const @ 0x00000000396522a9 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1004: DB::MergeTask::VerticalMergeStage::execute() @ 0x0000000039651c40 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x00000000396504a0 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3c455d 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:23.068439 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:23.734827 [ 4694 ] {e2af7a83-3ab2-4691-9b10-658c0a8c53b7} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, jobs=0): (while reading column y): (while reading from part /var/lib/clickhouse/store/6a9/6a9dd6b3-bc67-4638-b78e-461dda2d048a/all_10_10_0/ in table test_15.test (6a9dd6b3-bc67-4638-b78e-461dda2d048a) located on disk default of type local, from mark 0 with max_rows_to_read = 3): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:52802) (comment: 02941_variant_type_alters.sh) (in query: SELECT `__table1`.`x` AS `x`, `__table1`.`y` AS `y`, `__table1`.`y.UInt64` AS `y.UInt64`, `__table1`.`y.String` AS `y.String`, `__table1`.`v` AS `v`, `__table1`.`v.String` AS `v.String`, `__table1`.`v.UInt64` AS `v.UInt64`, `__table1`.`v.Date` AS `v.Date` FROM `test_15`.`test` AS `__table1` ORDER BY `__table1`.`x` 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000003075641a 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030755c60 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000307521d1 9. ./src/IO/AsynchronousReader.h:48: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000003073084e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000003073196f 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:163: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x00000000320e5233 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:22: DB::CompressedReadBufferFromFile::nextImpl() @ 0x00000000320eb1b7 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::nextImpl() @ 0x00000000320eb74d 15. DB::ReadBuffer::next() @ 0x00000000095b468f 16. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:168: DB::MergeTreeMarksLoader::loadMarksImpl() @ 0x0000000039c0e588 17. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:216: DB::MergeTreeMarksLoader::loadMarksSync() @ 0x0000000039c0a34d 18. ./src/Common/threadPoolCallbackRunner.h:0: std::__packaged_task_func> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)::operator()(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)::'lambda'(), std::allocator> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)::operator()(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)::'lambda'()>, std::shared_ptr ()>::operator()() @ 0x0000000039c12b04 19. ./contrib/llvm-project/libcxx/include/future:1953: std::packaged_task ()>::operator()() @ 0x0000000039c1a8c2 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039c12e0e 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 24. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 26. ? @ 0x00007f100c857ac3 27. ? @ 0x00007f100c8e9850 2025.10.23 23:36:23.740693 [ 4694 ] {e2af7a83-3ab2-4691-9b10-658c0a8c53b7} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, jobs=0): (while reading column y): (while reading from part /var/lib/clickhouse/store/6a9/6a9dd6b3-bc67-4638-b78e-461dda2d048a/all_10_10_0/ in table test_15.test (6a9dd6b3-bc67-4638-b78e-461dda2d048a) located on disk default of type local, from mark 0 with max_rows_to_read = 3): 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000003075641a 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030755c60 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000307521d1 9. ./src/IO/AsynchronousReader.h:48: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000003073084e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000003073196f 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:163: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x00000000320e5233 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:22: DB::CompressedReadBufferFromFile::nextImpl() @ 0x00000000320eb1b7 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::nextImpl() @ 0x00000000320eb74d 15. DB::ReadBuffer::next() @ 0x00000000095b468f 16. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:168: DB::MergeTreeMarksLoader::loadMarksImpl() @ 0x0000000039c0e588 17. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:216: DB::MergeTreeMarksLoader::loadMarksSync() @ 0x0000000039c0a34d 18. ./src/Common/threadPoolCallbackRunner.h:0: std::__packaged_task_func> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)::operator()(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)::'lambda'(), std::allocator> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)::operator()(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)::'lambda'()>, std::shared_ptr ()>::operator()() @ 0x0000000039c12b04 19. ./contrib/llvm-project/libcxx/include/future:1953: std::packaged_task ()>::operator()() @ 0x0000000039c1a8c2 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039c12e0e 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 24. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 26. ? @ 0x00007f100c857ac3 27. ? @ 0x00007f100c8e9850 2025.10.23 23:36:24.028615 [ 3657 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {d60c8165-1f8c-4cd1-8084-8b8c63363ea3::202510_1_48_9}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 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) @ 0x0000000039c89948 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000003999bfb7 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 @ 0x00000000399942f0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000039d15c04 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&) @ 0x0000000039d20399 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) @ 0x0000000039d1c606 15. ./contrib/llvm-project/libcxx/include/optional:260: DB::MergeTask::VerticalMergeStage::createPipeForReadingOneColumn(String const&) const @ 0x000000003963fa21 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::prepareVerticalMergeForOneColumn() const @ 0x0000000039641691 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::executeVerticalMergeForAllColumns() const @ 0x00000000396522a9 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1004: DB::MergeTask::VerticalMergeStage::execute() @ 0x0000000039651c40 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x00000000396504a0 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3c455d 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:24.147765 [ 2903 ] {ef520ece-a427-4780-924f-6bbfaffbdcf2} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.8:9000. DB::Exception: Cannot schedule a task: fault injected (threads=15, jobs=0): (while reading column y): (while reading from part /var/lib/clickhouse/store/6a9/6a9dd6b3-bc67-4638-b78e-461dda2d048a/all_10_10_0/ in table test_15.test (6a9dd6b3-bc67-4638-b78e-461dda2d048a) located on disk default of type local, from mark 0 with max_rows_to_read = 3): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000003075641a 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030755c60 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000307521d1 9. ./src/IO/AsynchronousReader.h:48: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000003073084e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000003073196f 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:163: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x00000000320e5233 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:22: DB::CompressedReadBufferFromFile::nextImpl() @ 0x00000000320eb1b7 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::nextImpl() @ 0x00000000320eb74d 15. DB::ReadBuffer::next() @ 0x00000000095b468f 16. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:168: DB::MergeTreeMarksLoader::loadMarksImpl() @ 0x0000000039c0e588 17. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:216: DB::MergeTreeMarksLoader::loadMarksSync() @ 0x0000000039c0a34d 18. ./src/Common/threadPoolCallbackRunner.h:0: std::__packaged_task_func> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)::operator()(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)::'lambda'(), std::allocator> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)::operator()(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)::'lambda'()>, std::shared_ptr ()>::operator()() @ 0x0000000039c12b04 19. ./contrib/llvm-project/libcxx/include/future:1953: std::packaged_task ()>::operator()() @ 0x0000000039c1a8c2 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039c12e0e 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 24. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 26. ? @ 0x00007f100c857ac3 27. ? @ 0x00007f100c8e9850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:39398) (comment: 02941_variant_type_alters.sh) (in query: select x, y, y.UInt64, y.String, v, v.String, v.UInt64, v.Date from test 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002019af32 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000003a7e3e0c 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::Connection::receivePacket() @ 0x000000003a7ff61b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:340: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003a8df9b9 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:0: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000032358b71 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000323566d1 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032355a26 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000032352f12 2025.10.23 23:36:24.154132 [ 9434 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:24.156456 [ 2903 ] {ef520ece-a427-4780-924f-6bbfaffbdcf2} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.8:9000. DB::Exception: Cannot schedule a task: fault injected (threads=15, jobs=0): (while reading column y): (while reading from part /var/lib/clickhouse/store/6a9/6a9dd6b3-bc67-4638-b78e-461dda2d048a/all_10_10_0/ in table test_15.test (6a9dd6b3-bc67-4638-b78e-461dda2d048a) located on disk default of type local, from mark 0 with max_rows_to_read = 3): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000003075641a 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030755c60 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000307521d1 9. ./src/IO/AsynchronousReader.h:48: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000003073084e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000003073196f 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:163: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x00000000320e5233 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:22: DB::CompressedReadBufferFromFile::nextImpl() @ 0x00000000320eb1b7 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::nextImpl() @ 0x00000000320eb74d 15. DB::ReadBuffer::next() @ 0x00000000095b468f 16. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:168: DB::MergeTreeMarksLoader::loadMarksImpl() @ 0x0000000039c0e588 17. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:216: DB::MergeTreeMarksLoader::loadMarksSync() @ 0x0000000039c0a34d 18. ./src/Common/threadPoolCallbackRunner.h:0: std::__packaged_task_func> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)::operator()(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)::'lambda'(), std::allocator> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)::operator()(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)::'lambda'()>, std::shared_ptr ()>::operator()() @ 0x0000000039c12b04 19. ./contrib/llvm-project/libcxx/include/future:1953: std::packaged_task ()>::operator()() @ 0x0000000039c1a8c2 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039c12e0e 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 24. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 26. ? @ 0x00007f100c857ac3 27. ? @ 0x00007f100c8e9850 : 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002019af32 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000003a7e3e0c 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::Connection::receivePacket() @ 0x000000003a7ff61b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:340: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003a8df9b9 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:0: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000032358b71 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000323566d1 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032355a26 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000032352f12 2025.10.23 23:36:25.116181 [ 3649 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {d60c8165-1f8c-4cd1-8084-8b8c63363ea3::202510_1_48_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 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) @ 0x0000000039c89948 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000003999bfb7 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 @ 0x00000000399942f0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000039d15c04 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&) @ 0x0000000039d20399 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) @ 0x0000000039d1c606 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000396308a4 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x00000000396235dd 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000003963b3e0 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x00000000396504a0 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3c455d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:25.198044 [ 9434 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:25.885841 [ 9678 ] {c9d930b0-6b3e-4c88-a5b2-19636d9e4aca} executeQuery: Code: 210. DB::Exception: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.7]:9000 -> [::ffff:127.0.0.1]:59926): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (NETWORK_ERROR) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:59926) (comment: 02941_variant_type_alters.sh) (in query: SELECT `__table1`.`x` AS `x`, `__table1`.`y` AS `y`, `__table1`.`y.UInt64` AS `y.UInt64`, `__table1`.`y.String` AS `y.String`, `__table1`.`v` AS `v`, `__table1`.`v.String` AS `v.String`, `__table1`.`v.UInt64` AS `v.UInt64`, `__table1`.`v.Date` AS `v.Date` FROM `test_15`.`test` AS `__table1` ORDER BY `__table1`.`x` 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c6938 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendMergeTreeReadTaskRequestAssumeLocked(DB::ParallelReadRequest) @ 0x000000003ac11a15 6. ./build_docker/./src/Server/TCPHandler.cpp:0: std::optional std::__function::__policy_invoker (DB::ParallelReadRequest)>::__call_impl (DB::ParallelReadRequest)>>(std::__function::__policy_storage const*, DB::ParallelReadRequest&&) @ 0x000000003ac32c20 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039d3ff1f 8. ./src/Storages/MergeTree/RequestResponse.h:44: DB::ParallelReadingExtension::sendReadRequest(DB::CoordinationMode, unsigned long, DB::RangesInDataPartsDescription const&) const @ 0x0000000039d357d7 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolParallelReplicas.cpp:0: DB::MergeTreeReadPoolParallelReplicas::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c0620b1 10. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:37: DB::MergeTreeThreadSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003bf806f4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d3c440 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf89b85 13. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 22. ? @ 0x00007f100c857ac3 23. ? @ 0x00007f100c8e9850 2025.10.23 23:36:25.885934 [ 9558 ] {386d7db6-a203-4540-bb40-c0524a16fb0a} executeQuery: Code: 210. DB::Exception: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.10]:9000 -> [::ffff:127.0.0.1]:46268): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (NETWORK_ERROR) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:46268) (comment: 02941_variant_type_alters.sh) (in query: SELECT `__table1`.`x` AS `x`, `__table1`.`y` AS `y`, `__table1`.`y.UInt64` AS `y.UInt64`, `__table1`.`y.String` AS `y.String`, `__table1`.`v` AS `v`, `__table1`.`v.String` AS `v.String`, `__table1`.`v.UInt64` AS `v.UInt64`, `__table1`.`v.Date` AS `v.Date` FROM `test_15`.`test` AS `__table1` ORDER BY `__table1`.`x` 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c6938 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendMergeTreeReadTaskRequestAssumeLocked(DB::ParallelReadRequest) @ 0x000000003ac11a15 6. ./build_docker/./src/Server/TCPHandler.cpp:0: std::optional std::__function::__policy_invoker (DB::ParallelReadRequest)>::__call_impl (DB::ParallelReadRequest)>>(std::__function::__policy_storage const*, DB::ParallelReadRequest&&) @ 0x000000003ac32c20 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039d3ff1f 8. ./src/Storages/MergeTree/RequestResponse.h:44: DB::ParallelReadingExtension::sendReadRequest(DB::CoordinationMode, unsigned long, DB::RangesInDataPartsDescription const&) const @ 0x0000000039d357d7 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolParallelReplicas.cpp:0: DB::MergeTreeReadPoolParallelReplicas::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c0620b1 10. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:37: DB::MergeTreeThreadSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003bf806f4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d3c440 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf89b85 13. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 22. ? @ 0x00007f100c857ac3 23. ? @ 0x00007f100c8e9850 2025.10.23 23:36:25.889420 [ 9678 ] {c9d930b0-6b3e-4c88-a5b2-19636d9e4aca} 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]:59926). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c6938 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000003ac2dd9a 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x000000003abff96a 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9aa8 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:25.889459 [ 9558 ] {386d7db6-a203-4540-bb40-c0524a16fb0a} 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]:46268). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c6938 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000003ac2dd9a 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x000000003abff96a 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9aa8 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:25.889783 [ 9678 ] {c9d930b0-6b3e-4c88-a5b2-19636d9e4aca} TCPHandler: Code: 210. DB::Exception: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.7]:9000 -> [::ffff:127.0.0.1]:59926): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c6938 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendMergeTreeReadTaskRequestAssumeLocked(DB::ParallelReadRequest) @ 0x000000003ac11a15 6. ./build_docker/./src/Server/TCPHandler.cpp:0: std::optional std::__function::__policy_invoker (DB::ParallelReadRequest)>::__call_impl (DB::ParallelReadRequest)>>(std::__function::__policy_storage const*, DB::ParallelReadRequest&&) @ 0x000000003ac32c20 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039d3ff1f 8. ./src/Storages/MergeTree/RequestResponse.h:44: DB::ParallelReadingExtension::sendReadRequest(DB::CoordinationMode, unsigned long, DB::RangesInDataPartsDescription const&) const @ 0x0000000039d357d7 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolParallelReplicas.cpp:0: DB::MergeTreeReadPoolParallelReplicas::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c0620b1 10. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:37: DB::MergeTreeThreadSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003bf806f4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d3c440 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf89b85 13. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 22. ? @ 0x00007f100c857ac3 23. ? @ 0x00007f100c8e9850 2025.10.23 23:36:25.889793 [ 9558 ] {386d7db6-a203-4540-bb40-c0524a16fb0a} TCPHandler: Code: 210. DB::Exception: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.10]:9000 -> [::ffff:127.0.0.1]:46268): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c6938 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendMergeTreeReadTaskRequestAssumeLocked(DB::ParallelReadRequest) @ 0x000000003ac11a15 6. ./build_docker/./src/Server/TCPHandler.cpp:0: std::optional std::__function::__policy_invoker (DB::ParallelReadRequest)>::__call_impl (DB::ParallelReadRequest)>>(std::__function::__policy_storage const*, DB::ParallelReadRequest&&) @ 0x000000003ac32c20 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039d3ff1f 8. ./src/Storages/MergeTree/RequestResponse.h:44: DB::ParallelReadingExtension::sendReadRequest(DB::CoordinationMode, unsigned long, DB::RangesInDataPartsDescription const&) const @ 0x0000000039d357d7 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolParallelReplicas.cpp:0: DB::MergeTreeReadPoolParallelReplicas::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c0620b1 10. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:37: DB::MergeTreeThreadSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003bf806f4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d3c440 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf89b85 13. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 22. ? @ 0x00007f100c857ac3 23. ? @ 0x00007f100c8e9850 2025.10.23 23:36:25.890485 [ 9678 ] {c9d930b0-6b3e-4c88-a5b2-19636d9e4aca} TCPHandler: Client has gone away. 2025.10.23 23:36:25.890600 [ 9558 ] {386d7db6-a203-4540-bb40-c0524a16fb0a} TCPHandler: Client has gone away. 2025.10.23 23:36:25.928911 [ 3647 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {d60c8165-1f8c-4cd1-8084-8b8c63363ea3::202510_1_48_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 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) @ 0x0000000039c89948 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000003999bfb7 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 @ 0x00000000399942f0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000039d15c04 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&) @ 0x0000000039d20399 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) @ 0x0000000039d1c606 15. ./contrib/llvm-project/libcxx/include/optional:260: DB::MergeTask::VerticalMergeStage::createPipeForReadingOneColumn(String const&) const @ 0x000000003963fa21 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::prepareVerticalMergeForOneColumn() const @ 0x0000000039641691 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::executeVerticalMergeForAllColumns() const @ 0x00000000396522a9 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1004: DB::MergeTask::VerticalMergeStage::execute() @ 0x0000000039651c40 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x00000000396504a0 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3c455d 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:26.330266 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:27.293208 [ 2903 ] {2b6471c3-c035-456c-b976-e596d491d0ff} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=765, jobs=743). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:34950) (comment: 02813_series_period_detect.sql) (in query: SELECT seriesPeriodDetectFFT([10, 20, 30, 10, 20, 30, 10, 20, 30, 10, 20, 30, 10, 20, 30, 10, 20, 30, 10, 20, 30]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:36:27.294486 [ 2903 ] {2b6471c3-c035-456c-b976-e596d491d0ff} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=765, 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:36:27.339968 [ 9678 ] {e3263beb-2391-4bd7-a1e3-7d4cf74b0901} executeQuery: Code: 630. DB::Exception: Cannot drop or rename test_jmew3eys.Mapping (59e3c48e-013c-415d-8d76-ad8a0a40f60b), because some tables depend on it: test_jmew3eys.Sub_distributed. (HAVE_DEPENDENT_OBJECTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:34922) (comment: 02916_joinget_dependency.sh) (in query: DROP TABLE Mapping;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x00000000339ef4ad 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1543: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x00000000339d48ff 5. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamed(DB::StorageID const&, bool, bool, bool) const @ 0x00000000339d6019 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003493f862 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:36:27.342103 [ 9678 ] {e3263beb-2391-4bd7-a1e3-7d4cf74b0901} TCPHandler: Code: 630. DB::Exception: Cannot drop or rename test_jmew3eys.Mapping (59e3c48e-013c-415d-8d76-ad8a0a40f60b), because some tables depend on it: test_jmew3eys.Sub_distributed. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x00000000339ef4ad 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1543: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x00000000339d48ff 5. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamed(DB::StorageID const&, bool, bool, bool) const @ 0x00000000339d6019 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003493f862 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:36:27.394095 [ 3894 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:28.070296 [ 9558 ] {3513d438-0d67-4d58-8335-03a84adca81a} executeQuery: Code: 630. DB::Exception: Cannot drop or rename test_jmew3eys.Mapping (59e3c48e-013c-415d-8d76-ad8a0a40f60b), because some tables depend on it: test_jmew3eys.Sub_distributed. (HAVE_DEPENDENT_OBJECTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:34980) (comment: 02916_joinget_dependency.sh) (in query: DROP TABLE Mapping;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x00000000339ef4ad 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1543: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x00000000339d48ff 5. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamed(DB::StorageID const&, bool, bool, bool) const @ 0x00000000339d6019 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003493f862 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:36:28.073937 [ 9558 ] {3513d438-0d67-4d58-8335-03a84adca81a} TCPHandler: Code: 630. DB::Exception: Cannot drop or rename test_jmew3eys.Mapping (59e3c48e-013c-415d-8d76-ad8a0a40f60b), because some tables depend on it: test_jmew3eys.Sub_distributed. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x00000000339ef4ad 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1543: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x00000000339d48ff 5. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamed(DB::StorageID const&, bool, bool, bool) const @ 0x00000000339d6019 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003493f862 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:36:28.482187 [ 9558 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:28.720193 [ 3657 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {d60c8165-1f8c-4cd1-8084-8b8c63363ea3::202510_1_48_9}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 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) @ 0x0000000039c89948 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000003999bfb7 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 @ 0x00000000399942f0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000039d15c04 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&) @ 0x0000000039d20399 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) @ 0x0000000039d1c606 15. ./contrib/llvm-project/libcxx/include/optional:260: DB::MergeTask::VerticalMergeStage::createPipeForReadingOneColumn(String const&) const @ 0x000000003963fa21 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::prepareVerticalMergeForOneColumn() const @ 0x0000000039641691 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::executeVerticalMergeForAllColumns() const @ 0x00000000396522a9 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1004: DB::MergeTask::VerticalMergeStage::execute() @ 0x0000000039651c40 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x00000000396504a0 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3c455d 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:29.222949 [ 2903 ] {026c7371-d5cd-4c6f-a1ee-705dffbf8221} executeQuery: Code: 59. DB::Exception: Invalid type for filter in WHERE: Tuple(a UInt64, b UInt64). In query SELECT x FROM tab ARRAY JOIN arr PREWHERE x != 0 WHERE arr. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:34964) (comment: 01674_where_prewhere_array_crash.sql) (in query: select x from tab array join arr prewhere x != 0 where arr;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x00000000319e1f37 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:50: DB::(anonymous namespace)::validateFilter(std::shared_ptr const&, std::basic_string_view>, std::shared_ptr const&) @ 0x000000003359040a 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::validateFilters(std::shared_ptr const&) @ 0x000000003358f743 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003343ad08 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:36:29.224223 [ 2903 ] {026c7371-d5cd-4c6f-a1ee-705dffbf8221} TCPHandler: Code: 59. DB::Exception: Invalid type for filter in WHERE: Tuple(a UInt64, b UInt64). In query SELECT x FROM tab ARRAY JOIN arr PREWHERE x != 0 WHERE arr. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x00000000319e1f37 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:50: DB::(anonymous namespace)::validateFilter(std::shared_ptr const&, std::basic_string_view>, std::shared_ptr const&) @ 0x000000003359040a 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::validateFilters(std::shared_ptr const&) @ 0x000000003358f743 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003343ad08 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:36:29.304263 [ 3643 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {d60c8165-1f8c-4cd1-8084-8b8c63363ea3::202510_1_48_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 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) @ 0x0000000039c89948 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000003999bfb7 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 @ 0x00000000399942f0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000039d15c04 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&) @ 0x0000000039d20399 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) @ 0x0000000039d1c606 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000396308a4 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x00000000396235dd 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000003963b3e0 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x00000000396504a0 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3c455d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:29.561441 [ 3894 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:30.678619 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:30.973090 [ 2903 ] {c2fc6253-9537-4320-a3be-3c648c8167f5} executeQuery: Code: 59. DB::Exception: Invalid type for filter in PREWHERE: Tuple(a UInt64, b UInt64). In query SELECT x FROM tab ARRAY JOIN arr PREWHERE arr WHERE x != 0. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:34964) (comment: 01674_where_prewhere_array_crash.sql) (in query: select x from tab array join arr prewhere arr where x != 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x00000000319e1f37 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:50: DB::(anonymous namespace)::validateFilter(std::shared_ptr const&, std::basic_string_view>, std::shared_ptr const&) @ 0x000000003359040a 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:0: DB::validateFilters(std::shared_ptr const&) @ 0x000000003358f5a9 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003343ad08 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:36:30.974397 [ 2903 ] {c2fc6253-9537-4320-a3be-3c648c8167f5} TCPHandler: Code: 59. DB::Exception: Invalid type for filter in PREWHERE: Tuple(a UInt64, b UInt64). In query SELECT x FROM tab ARRAY JOIN arr PREWHERE arr WHERE x != 0. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x00000000319e1f37 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:50: DB::(anonymous namespace)::validateFilter(std::shared_ptr const&, std::basic_string_view>, std::shared_ptr const&) @ 0x000000003359040a 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:0: DB::validateFilters(std::shared_ptr const&) @ 0x000000003358f5a9 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003343ad08 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:36:31.897772 [ 9453 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:31.946148 [ 3653 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {d60c8165-1f8c-4cd1-8084-8b8c63363ea3::202510_1_48_9}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 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) @ 0x0000000039c89948 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000003999bfb7 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 @ 0x00000000399942f0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000039d15c04 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&) @ 0x0000000039d20399 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) @ 0x0000000039d1c606 15. ./contrib/llvm-project/libcxx/include/optional:260: DB::MergeTask::VerticalMergeStage::createPipeForReadingOneColumn(String const&) const @ 0x000000003963fa21 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::prepareVerticalMergeForOneColumn() const @ 0x0000000039641691 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::executeVerticalMergeForAllColumns() const @ 0x00000000396522a9 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1004: DB::MergeTask::VerticalMergeStage::execute() @ 0x0000000039651c40 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x00000000396504a0 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3c455d 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:32.984677 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:34.023485 [ 9433 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:34.325433 [ 9557 ] {3649dbfb-bd6b-4077-8b54-75c675705ba1} executeQuery: Code: 57. DB::Exception: Table test_11.test already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03249_dynamic_alter_consistency.sql) (in query: /* ddl_entry=query-0000000042 */ CREATE TABLE test_11.test UUID '004a3246-8ffa-4613-9479-348f3213e26f' (`d` Dynamic) ENGINE = MergeTree ORDER BY tuple() SETTINGS min_rows_for_wide_part = 1, min_bytes_for_wide_part = 1, index_granularity = 53558, 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 = 10028288, compact_parts_max_bytes_to_buffer = 172763018, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 11346310, merge_max_block_size = 2668, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 7715656835, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 18194507, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 30135, primary_key_compress_block_size = 46194), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003395fc9e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000033958fac 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ad726d 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a52a3c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfab2 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:36:34.391605 [ 9557 ] {3649dbfb-bd6b-4077-8b54-75c675705ba1} executeQuery: Code: 57. DB::Exception: Table test_11.test already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:35090) (comment: 03249_dynamic_alter_consistency.sql) (in query: CREATE TABLE test (`d` Dynamic) ENGINE = MergeTree ORDER BY tuple() SETTINGS min_rows_for_wide_part = 1, min_bytes_for_wide_part = 1, index_granularity = 53558, 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 = 10028288, compact_parts_max_bytes_to_buffer = 172763018, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 11346310, merge_max_block_size = 2668, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 7715656835, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 18194507, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 30135, primary_key_compress_block_size = 46194), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003395fc9e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000033958fac 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ad726d 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a52a3c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfab2 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:36:34.394789 [ 9557 ] {3649dbfb-bd6b-4077-8b54-75c675705ba1} TCPHandler: Code: 57. DB::Exception: Table test_11.test already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003395fc9e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000033958fac 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ad726d 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a52a3c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfab2 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:36:35.094815 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:36.212986 [ 9433 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:37.322424 [ 9433 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:38.378871 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:39.448018 [ 9433 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:40.516609 [ 9433 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:41.035891 [ 6961 ] {0ded5eb1-3164-48ff-9efa-acc3c6000d45} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37952) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (in query: DROP DATABASE IF EXISTS test_79ykqgig ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:36:41.038858 [ 6961 ] {0ded5eb1-3164-48ff-9efa-acc3c6000d45} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:41.154102 [ 4799 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:41.337244 [ 9557 ] {7abe7d46-11e9-4685-b293-b08e98cf5165} executeQuery: Code: 386. DB::Exception: JOIN SEMI LEFT JOIN ... USING (id2) cannot infer common type for Int64 and UInt64 in USING for identifier 'id2'. In scope SELECT * FROM (SELECT toInt64(11) AS id2) AS js1 SEMI LEFT JOIN joinbug_join USING (id2). (NO_COMMON_TYPE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:55360) (comment: 00561_storage_join.sql) (in query: -- can't convert right side in case on storage join SELECT * FROM ( SELECT toInt64(11) AS id2 ) AS js1 SEMI LEFT JOIN joinbug_join USING (id2);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String const&, String&&) @ 0x0000000033502b87 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5142: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334f9c2a 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334edd53 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436960 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:36:41.339178 [ 9557 ] {7abe7d46-11e9-4685-b293-b08e98cf5165} TCPHandler: Code: 386. DB::Exception: JOIN SEMI LEFT JOIN ... USING (id2) cannot infer common type for Int64 and UInt64 in USING for identifier 'id2'. In scope SELECT * FROM (SELECT toInt64(11) AS id2) AS js1 SEMI LEFT JOIN joinbug_join USING (id2). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String const&, String&&) @ 0x0000000033502b87 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5142: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334f9c2a 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334edd53 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436960 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:36:41.584003 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:41.725489 [ 9557 ] {2676d7ee-f0f3-4d3d-8d20-e3856c25d8b5} executeQuery: Code: 60. DB::Exception: Table test_11.ghdata does not exist. (UNKNOWN_TABLE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:55420) (comment: 01825_type_json_ghdata.sh) (in query: INSERT INTO ghdata FORMAT JSONAsObject), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b14381 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:433: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000003399fc33 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:957: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339b4ac1 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000034b9ec4f 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000034bb99c8 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:41.821771 [ 9557 ] {2676d7ee-f0f3-4d3d-8d20-e3856c25d8b5} TCPHandler: Code: 60. DB::Exception: Table test_11.ghdata 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b14381 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:433: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000003399fc33 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:957: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339b4ac1 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000034b9ec4f 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000034bb99c8 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:42.552111 [ 9557 ] {e6b66049-04ef-4df9-9303-5c5f404708cc} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'ghdata' in scope SELECT count() FROM ghdata WHERE NOT ignore(*). (UNKNOWN_TABLE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:55448) (comment: 01825_type_json_ghdata.sh) (in query: SELECT count() FROM ghdata WHERE NOT ignore(*)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa0996d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334eae8a 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003343676d 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 2025.10.23 23:36:42.554078 [ 9557 ] {e6b66049-04ef-4df9-9303-5c5f404708cc} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'ghdata' in scope SELECT count() FROM ghdata WHERE NOT ignore(*). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa0996d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334eae8a 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003343676d 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 2025.10.23 23:36:42.651227 [ 9433 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:43.572176 [ 3651 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {9a375c2d-1765-4ead-bc63-7dc0959ac450::202510_73_103_6}: 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 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) @ 0x0000000039c89948 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000003999bfb7 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 @ 0x00000000399942f0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000039d15c04 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&) @ 0x0000000039d20399 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) @ 0x0000000039d1c606 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000396308a4 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x00000000396235dd 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000003963b3e0 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x00000000396504a0 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3c455d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:43.574328 [ 3647 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {d7361de3-cb90-4044-830f-20b9d940375a::202510_1_31_6}: 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 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) @ 0x0000000039c89948 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000003999bfb7 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 @ 0x00000000399942f0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000039d15c04 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&) @ 0x0000000039d20399 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) @ 0x0000000039d1c606 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000396308a4 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x00000000396235dd 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000003963b3e0 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x00000000396504a0 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3c455d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:43.774602 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:43.832602 [ 3757 ] {} ZooKeeperClient: Code: 999. Coordination::Exception: Session expired (fault injected on recv). (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000003a21d8b1 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEES0_NS_5ErrorEOS5_ @ 0x000000003cd2cd64 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1660: Coordination::ZooKeeper::maybeInjectRecvFault() @ 0x000000003cd156a2 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveEvent() @ 0x000000003cd1207c 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveThread() @ 0x000000003cd109b9 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl> const&, zkutil::ZooKeeperArgs const&, std::shared_ptr)::$_1>(Coordination::ZooKeeper::ZooKeeper(std::vector> const&, zkutil::ZooKeeperArgs const&, std::shared_ptr)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003cd2940f 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:43.833228 [ 3276 ] {} test_3.`02691_drop_column_replicated` (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.10.23 23:36:43.833334 [ 3161 ] {} test_3.rmt (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.10.23 23:36:43.833422 [ 3279 ] {} test_15.r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.10.23 23:36:43.833876 [ 3249 ] {} test_3.rmt (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /test/02253/02253_empty_part_checksums_test_3/rmt/log. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x0000000030538e6c 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000003cbf3b60 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003cbea871 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000003a0439c9 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a04133c 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:50: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a03dd98 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003a06697f 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:43.834007 [ 3290 ] {} test_3.rmt (1c58b3d3-3aa3-4fc2-81b4-6ea1ac046ae6): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/02253/02253_empty_part_checksums_test_3/rmt/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:43.834066 [ 3468 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000003cc8de51 3. ./src/Common/ZooKeeper/IKeeper.h:509: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003cd16a3e 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1383: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x000000003cd1a472 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x000000003cbf5306 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:610: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x000000003cbf42db 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000003cbf676b 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003cbf5ab3 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x000000003a0eb80c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889e7df 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:43.834096 [ 3074 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000003cc8de51 3. ./src/Common/ZooKeeper/IKeeper.h:509: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003cd16a3e 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003cd2369f 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe6e6d 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe5f26 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe84e7 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe81ea 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000003a10064e 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000003889f11d 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f9f 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:43.834117 [ 3557 ] {} test_3.rmt (1c58b3d3-3aa3-4fc2-81b4-6ea1ac046ae6): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000003cc8de51 3. ./src/Common/ZooKeeper/IKeeper.h:509: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003cd16a3e 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003cd2369f 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe6e6d 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe5f26 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe84e7 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe81ea 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000003a10064e 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000003889f11d 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f9f 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:43.835285 [ 3200 ] {} test_3.rmt (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000003cc8de51 3. ./src/Common/ZooKeeper/IKeeper.h:509: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003cd16a3e 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000003cd20792 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryExistsNoThrow(String const&, std::function) @ 0x000000003cbf3581 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003cbf26a1 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000003cbf3a70 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003cbea871 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000003a0439c9 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a04133c 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:50: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a03dd98 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003a06697f 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 15. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:44.444004 [ 4799 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:44.856401 [ 9433 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:45.003478 [ 9433 ] {474c0c54-d999-4ecb-ba96-c1f37fc2289f} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'ghdata' in scope SELECT data.repo.name, count() AS stars FROM ghdata WHERE data.type = 'WatchEvent' GROUP BY data.repo.name ORDER BY stars DESC, data.repo.name ASC LIMIT 5. (UNKNOWN_TABLE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59708) (comment: 01825_type_json_ghdata.sh) (in query: SELECT data.repo.name, count() AS stars FROM ghdata WHERE data.type = 'WatchEvent' GROUP BY data.repo.name ORDER BY stars DESC, data.repo.name LIMIT 5), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa0996d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334eae8a 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003343676d 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 2025.10.23 23:36:45.005830 [ 9433 ] {474c0c54-d999-4ecb-ba96-c1f37fc2289f} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'ghdata' in scope SELECT data.repo.name, count() AS stars FROM ghdata WHERE data.type = 'WatchEvent' GROUP BY data.repo.name ORDER BY stars DESC, data.repo.name ASC LIMIT 5. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa0996d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334eae8a 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003343676d 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 2025.10.23 23:36:45.022777 [ 4799 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:45.836004 [ 9433 ] {976cdf77-137a-41da-8b54-11ce31149e34} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'ghdata' in scope SELECT data.payload.commits.author.name AS name, count() AS c FROM ghdata ARRAY JOIN data.payload.commits.author.name GROUP BY name ORDER BY c DESC, name ASC LIMIT 5. (UNKNOWN_TABLE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59716) (comment: 01825_type_json_ghdata.sh) (in query: SELECT data.payload.commits.author.name AS name, count() AS c FROM ghdata ARRAY JOIN data.payload.commits.author.name GROUP BY name ORDER BY c DESC, name LIMIT 5), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa0996d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334eae8a 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003343676d 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 2025.10.23 23:36:45.838315 [ 9433 ] {976cdf77-137a-41da-8b54-11ce31149e34} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'ghdata' in scope SELECT data.payload.commits.author.name AS name, count() AS c FROM ghdata ARRAY JOIN data.payload.commits.author.name GROUP BY name ORDER BY c DESC, name ASC LIMIT 5. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa0996d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334eae8a 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003343676d 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 2025.10.23 23:36:46.038444 [ 4799 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:46.079667 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:46.566873 [ 9433 ] {ad307035-b427-4934-9993-7fc5c16725f6} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'ghdata' in scope SELECT max(data.payload.pull_request.assignees.size0) FROM ghdata. (UNKNOWN_TABLE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59750) (comment: 01825_type_json_ghdata.sh) (in query: SELECT max(data.payload.pull_request.assignees.size0) FROM ghdata), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa0996d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334eae8a 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003343676d 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 2025.10.23 23:36:46.569234 [ 9433 ] {ad307035-b427-4934-9993-7fc5c16725f6} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'ghdata' in scope SELECT max(data.payload.pull_request.assignees.size0) FROM ghdata. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa0996d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334eae8a 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003343676d 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 2025.10.23 23:36:47.094367 [ 9433 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:47.133008 [ 4799 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:48.140043 [ 4799 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:48.202729 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:49.189226 [ 4799 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:49.269839 [ 4799 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:50.209702 [ 9433 ] {13926df6-de20-4218-ace9-755f2abb4053} executeQuery: Code: 57. DB::Exception: Table test_11.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02691_multiple_joins_backtick_identifiers.sql) (in query: /* ddl_entry=query-0000000044 */ CREATE TABLE test_11.t1 UUID '59f62c2b-f686-414a-8c6a-7a71d128a2e6' (`1a` Nullable(Int64), `2b` Nullable(String)) ENGINE = Memory), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003395fc9e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000033958fac 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ad726d 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a52a3c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfab2 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:36:50.221220 [ 4799 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:50.293043 [ 9433 ] {13926df6-de20-4218-ace9-755f2abb4053} executeQuery: Code: 57. DB::Exception: Table test_11.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59856) (comment: 02691_multiple_joins_backtick_identifiers.sql) (in query: CREATE TABLE t1 (`1a` Nullable(Int64), `2b` Nullable(String)) engine = Memory;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003395fc9e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000033958fac 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ad726d 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a52a3c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfab2 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:36:50.296502 [ 9433 ] {13926df6-de20-4218-ace9-755f2abb4053} TCPHandler: Code: 57. DB::Exception: Table test_11.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003395fc9e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000033958fac 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ad726d 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a52a3c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfab2 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:36:50.355638 [ 4799 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:51.052936 [ 9433 ] {eb057a37-bdae-4233-8745-8b9732c07f94} executeQuery: Code: 57. DB::Exception: Table test_11.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 00118_storage_join.sql) (in query: /* ddl_entry=query-0000000045 */ CREATE TABLE test_11.t2 UUID '25024e43-56ea-41e6-8d3a-47f2f85b2c32' (`k` UInt64, `s` String) ENGINE = Join(ANY, LEFT, k)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003395fc9e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000033958fac 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ad726d 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a52a3c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfab2 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:36:51.059249 [ 9433 ] {eb057a37-bdae-4233-8745-8b9732c07f94} executeQuery: Code: 57. DB::Exception: Table test_11.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59890) (comment: 00118_storage_join.sql) (in query: CREATE TABLE t2 (k UInt64, s String) ENGINE = Join(ANY, LEFT, k);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003395fc9e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000033958fac 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ad726d 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a52a3c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfab2 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:36:51.067157 [ 9433 ] {eb057a37-bdae-4233-8745-8b9732c07f94} TCPHandler: Code: 57. DB::Exception: Table test_11.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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003395fc9e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000033958fac 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ad726d 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a52a3c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfab2 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:36:51.300667 [ 9433 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:51.667894 [ 9433 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:52.428259 [ 4799 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:52.716978 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:53.475826 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:53.746927 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:53.779662 [ 4799 ] {1dc18daf-9e8d-40cb-a008-d88e0c1006ac} executeQuery: Code: 264. DB::Exception: Table test_p2ojyerz.t2 (d1c166b2-f2a8-4b2e-b514-39d9f3768699) needs the same join_use_nulls setting as present in LEFT or FULL JOIN. (INCOMPATIBLE_TYPE_OF_JOIN) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59958) (comment: 00119_storage_join.sql) (in query: SELECT k, s FROM (SELECT number AS k FROM system.numbers LIMIT 10) js1 ANY LEFT JOIN t2 USING k;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Storages/StorageJoin.cpp:239: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x0000000038412c84 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&) @ 0x0000000034de998c 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&) @ 0x0000000034d95d85 7. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d6a797 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0b8de 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cfd8b2 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034cf6172 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5bf1 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:36:53.781766 [ 4799 ] {1dc18daf-9e8d-40cb-a008-d88e0c1006ac} TCPHandler: Code: 264. DB::Exception: Table test_p2ojyerz.t2 (d1c166b2-f2a8-4b2e-b514-39d9f3768699) needs the same join_use_nulls setting as present in LEFT or FULL JOIN. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Storages/StorageJoin.cpp:239: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x0000000038412c84 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&) @ 0x0000000034de998c 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&) @ 0x0000000034d95d85 7. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d6a797 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0b8de 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cfd8b2 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034cf6172 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5bf1 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:36:53.931413 [ 4799 ] {908c2193-21cd-4dca-a4e5-1e8b4e60cee7} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:33350) (comment: 00119_storage_join.sql) (in query: DROP DATABASE IF EXISTS test_p2ojyerz ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:36:53.970873 [ 4799 ] {908c2193-21cd-4dca-a4e5-1e8b4e60cee7} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:53.990382 [ 6965 ] {3bee6e75-2572-4e4c-879a-b20f50a22c3b} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:33358) (comment: 00119_storage_join.sql) (in query: DROP DATABASE IF EXISTS test_p2ojyerz ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:36:54.041556 [ 6965 ] {3bee6e75-2572-4e4c-879a-b20f50a22c3b} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:54.076118 [ 4799 ] {62758695-6bd4-476d-b878-14ea2fb51fb8} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:33372) (comment: 00119_storage_join.sql) (in query: DROP DATABASE IF EXISTS test_p2ojyerz ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:36:54.078869 [ 4799 ] {62758695-6bd4-476d-b878-14ea2fb51fb8} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:54.571019 [ 4799 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:54.800656 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:55.618286 [ 4799 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:55.687638 [ 6965 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:55.874174 [ 4799 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:56.719407 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:56.754140 [ 3365 ] {} test_3.`02691_drop_column_replicated` (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.10.23 23:36:56.754259 [ 3174 ] {} test_3.rmt (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.10.23 23:36:56.754361 [ 3549 ] {} test_15.r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.10.23 23:36:56.754847 [ 3521 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02725_start_stop_fetches_test_15/r/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:56.755031 [ 3346 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000003cc8de51 3. ./src/Common/ZooKeeper/IKeeper.h:509: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003cd16a3e 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003cd2369f 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe6e6d 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe5f26 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe84e7 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe81ea 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000003a10064e 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000003889f11d 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f9f 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:56.918239 [ 3903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:57.840900 [ 6965 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:58.023831 [ 3534 ] {} test_3.rmt (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Session expired (fault injected on send). (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000003a21d8b1 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEES0_NS_5ErrorEOS5_ @ 0x000000003cd2cd64 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1654: Coordination::ZooKeeper::maybeInjectSendFault() @ 0x000000003cd17122 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003cd165e8 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003cd2369f 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe6e6d 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe5f26 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe84e7 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000003cbe7761 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x000000003a061e9e 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x000000003a04fe19 13. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a041419 14. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:50: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a03dd98 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003a06697f 16. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 18. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 21. ? @ 0x00007f100c857ac3 22. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:58.085832 [ 6965 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:58.630554 [ 6965 ] {d83a607c-3bec-4a6b-899f-79955c445274} executeQuery: Code: 57. DB::Exception: Table test_11.optimize_sorting already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02377_optimize_sorting_by_input_stream_properties_explain.sh) (in query: /* ddl_entry=query-0000000048 */ CREATE TABLE test_11.optimize_sorting UUID '5e2e77e2-a7c7-4fc6-a676-7f6f5c6ced0c' (`a` UInt64, `b` UInt64, `c` UInt64) ENGINE = MergeTree ORDER BY (a, b) SETTINGS index_granularity = 6061, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 277954889, compact_parts_max_granules_to_buffer = 225, compact_parts_merge_max_bytes_to_prefetch_part = 33379503, merge_max_block_size = 19714, old_parts_lifetime = 215., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 5094767, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 49179, primary_key_compress_block_size = 92029), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003395fc9e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000033958fac 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ad726d 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a52a3c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfab2 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:36:58.702422 [ 3466 ] {} test_3.`02691_drop_column_replicated` (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.10.23 23:36:58.702595 [ 3069 ] {} test_3.rmt (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.10.23 23:36:58.702763 [ 3507 ] {} test_15.r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.10.23 23:36:58.703428 [ 3395 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02725_start_stop_fetches_test_15/r/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:58.704283 [ 3162 ] {} test_3.`02691_drop_column_replicated` (1045b1a8-f37f-4f75-892a-b44e770b298b): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000003cc8de51 3. ./src/Common/ZooKeeper/IKeeper.h:509: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003cd16a3e 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003cd2369f 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe6e6d 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe5f26 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe84e7 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe81ea 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000003a10064e 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000003889f11d 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f9f 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:58.716379 [ 6965 ] {d83a607c-3bec-4a6b-899f-79955c445274} executeQuery: Code: 57. DB::Exception: Table test_11.optimize_sorting already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:35686) (comment: 02377_optimize_sorting_by_input_stream_properties_explain.sh) (in query: CREATE TABLE optimize_sorting (`a` UInt64, `b` UInt64, `c` UInt64) ENGINE = MergeTree ORDER BY (a, b) SETTINGS index_granularity = 6061, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 277954889, compact_parts_max_granules_to_buffer = 225, compact_parts_merge_max_bytes_to_prefetch_part = 33379503, merge_max_block_size = 19714, old_parts_lifetime = 215., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 5094767, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 49179, primary_key_compress_block_size = 92029), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003395fc9e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000033958fac 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ad726d 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a52a3c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfab2 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:36:58.718690 [ 6965 ] {d83a607c-3bec-4a6b-899f-79955c445274} TCPHandler: Code: 57. DB::Exception: Table test_11.optimize_sorting already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003395fc9e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000033958fac 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ad726d 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a52a3c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfab2 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:36:58.752075 [ 3453 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000003cc8de51 3. ./src/Common/ZooKeeper/IKeeper.h:509: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003cd16a3e 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003cd2369f 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe6e6d 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe5f26 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe84e7 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe81ea 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000003a10064e 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000003889f11d 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f9f 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:58.905195 [ 4649 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:59.137278 [ 6965 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:36:59.986909 [ 3895 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:00.273163 [ 6965 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:00.874815 [ 3229 ] {} test_3.rmt (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Session expired (fault injected on send). (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000003a21d8b1 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEES0_NS_5ErrorEOS5_ @ 0x000000003cd2cd64 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1654: Coordination::ZooKeeper::maybeInjectSendFault() @ 0x000000003cd17122 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003cd165e8 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000003cd20792 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryExistsNoThrow(String const&, std::function) @ 0x000000003cbf3581 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003cbf26a1 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000003cbf3a70 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003cbea871 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000003a0439c9 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a04133c 13. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:50: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a03dd98 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003a06697f 15. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 17. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:01.185138 [ 6965 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:01.326921 [ 3895 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:02.239822 [ 3895 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:02.346384 [ 3895 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:03.300542 [ 3895 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:03.366214 [ 6965 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:03.849363 [ 3649 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b37203c3-8fb0-4cdf-8555-9946d278f55b::202510_1_50_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 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) @ 0x0000000039c89948 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000003999bfb7 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 @ 0x00000000399942f0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000039d15c04 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&) @ 0x0000000039d20399 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) @ 0x0000000039d1c606 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000396308a4 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x00000000396235dd 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000003963b3e0 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x00000000396504a0 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3c455d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:04.341874 [ 3895 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:04.358732 [ 3657 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {9a375c2d-1765-4ead-bc63-7dc0959ac450::202510_73_108_7}: 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 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) @ 0x0000000039c89948 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000003999bfb7 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 @ 0x00000000399942f0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000039d15c04 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&) @ 0x0000000039d20399 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) @ 0x0000000039d1c606 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000396308a4 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x00000000396235dd 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000003963b3e0 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x00000000396504a0 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3c455d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:04.396574 [ 4745 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:04.570883 [ 4649 ] {45926487-cee6-41a7-86e1-d2cfb8c614c1} executeQuery: Code: 122. DB::Exception: Tables have different structure. (INCOMPATIBLE_COLUMNS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:35804) (comment: 02998_attach_partition_not_allowed_if_structure_differs_due_to_materialized_column.sql) (in query: ALTER TABLE attach_partition_t8 ATTACH PARTITION ID '1' FROM attach_partition_t7;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkStructureAndGetMergeTreeData(DB::IStorage&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x00000000398537ca 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7319: DB::MergeTreeData::checkStructureAndGetMergeTreeData(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x00000000398546ff 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::replacePartitionFrom(std::shared_ptr const&, std::shared_ptr const&, bool, std::shared_ptr) @ 0x000000003a363eeb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x00000000397ec7b0 8. ./src/QueryPipeline/Pipe.h:45: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034867310 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003485e550 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:37:04.572633 [ 4649 ] {45926487-cee6-41a7-86e1-d2cfb8c614c1} TCPHandler: Code: 122. DB::Exception: Tables have different structure. (INCOMPATIBLE_COLUMNS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkStructureAndGetMergeTreeData(DB::IStorage&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x00000000398537ca 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7319: DB::MergeTreeData::checkStructureAndGetMergeTreeData(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x00000000398546ff 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::replacePartitionFrom(std::shared_ptr const&, std::shared_ptr const&, bool, std::shared_ptr) @ 0x000000003a363eeb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x00000000397ec7b0 8. ./src/QueryPipeline/Pipe.h:45: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034867310 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003485e550 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:37:04.599554 [ 6965 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:05.033838 [ 4841 ] {6e41fc9c-49bf-40fb-96d2-667dc4923d6a} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::1]:9000 -> [::1]:35742). (NETWORK_ERROR) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:35742) (comment: 02003_memory_limit_in_client.sh) (in query: SELECT arrayMap(x -> range(x), range(number)) FROM numbers(1000) -- { clientError MEMORY_LIMIT_EXCEEDED }), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:158: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c63a0 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. DB::WriteBuffer::write(char const*, unsigned long) @ 0x00000000083dcce5 6. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:213: DB::SerializationNumber::serializeBinaryBulk(DB::IColumn const&, DB::WriteBuffer&, unsigned long, unsigned long) const @ 0x0000000032795a95 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1551: DB::SerializationArray::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x000000003266762d 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:63: DB::SerializationArray::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x00000000326678f0 9. ./build_docker/./src/Formats/NativeWriter.cpp:76: DB::NativeWriter::write(DB::Block const&) @ 0x000000003ada696b 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000003ac04275 11. ./contrib/llvm-project/libcxx/include/__mutex_base:253: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfbb15 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:37:05.035384 [ 4841 ] {6e41fc9c-49bf-40fb-96d2-667dc4923d6a} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::1]:9000 -> [::1]:35742). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:158: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c63a0 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. DB::WriteBuffer::write(char const*, unsigned long) @ 0x00000000083dcce5 6. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:213: DB::SerializationNumber::serializeBinaryBulk(DB::IColumn const&, DB::WriteBuffer&, unsigned long, unsigned long) const @ 0x0000000032795a95 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1551: DB::SerializationArray::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x000000003266762d 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:63: DB::SerializationArray::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x00000000326678f0 9. ./build_docker/./src/Formats/NativeWriter.cpp:76: DB::NativeWriter::write(DB::Block const&) @ 0x000000003ada696b 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000003ac04275 11. ./contrib/llvm-project/libcxx/include/__mutex_base:253: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfbb15 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:37:05.035922 [ 4841 ] {6e41fc9c-49bf-40fb-96d2-667dc4923d6a} TCPHandler: Client has gone away. 2025.10.23 23:37:05.489764 [ 4745 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:05.509401 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:06.185837 [ 3895 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:06.607853 [ 3895 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:06.624461 [ 4745 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:06.723501 [ 3485 ] {} test_3.`02691_drop_column_replicated` (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.10.23 23:37:06.723631 [ 3110 ] {} test_3.rmt (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.10.23 23:37:06.723997 [ 3558 ] {} test_15.r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.10.23 23:37:06.724435 [ 3343 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02725_start_stop_fetches_test_15/r/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:06.724698 [ 3456 ] {} test_3.rmt (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Session expired (fault injected on send). (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000003a21d8b1 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEES0_NS_5ErrorEOS5_ @ 0x000000003cd2cd64 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1654: Coordination::ZooKeeper::maybeInjectSendFault() @ 0x000000003cd17122 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003cd165e8 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003cd2369f 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe6e6d 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe5f26 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe84e7 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000003cbe7761 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x000000003a061e9e 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x000000003a04fe19 13. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:165: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a04156e 14. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:50: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a03dd98 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003a06697f 16. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 18. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 21. ? @ 0x00007f100c857ac3 22. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:06.724740 [ 3479 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000003cc8de51 3. ./src/Common/ZooKeeper/IKeeper.h:509: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003cd16a3e 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003cd2369f 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe6e6d 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe5f26 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe84e7 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe81ea 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000003a10064e 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000003889f11d 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f9f 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:07.700299 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:07.721987 [ 4745 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:07.830653 [ 4745 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:08.041936 [ 4649 ] {51e899f7-e069-4cd2-9b7b-1a250837d951} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::1]:9000 -> [::1]:51994). (NETWORK_ERROR) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:51994) (comment: 02003_memory_limit_in_client.sh) (in query: SELECT arrayMap(x -> range(x), range(number)) FROM numbers(1000) -- { clientError MEMORY_LIMIT_EXCEEDED }), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:158: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c63a0 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. DB::WriteBuffer::write(char const*, unsigned long) @ 0x00000000083dcce5 6. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:213: DB::SerializationNumber::serializeBinaryBulk(DB::IColumn const&, DB::WriteBuffer&, unsigned long, unsigned long) const @ 0x0000000032795a95 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1551: DB::SerializationArray::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x000000003266762d 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:63: DB::SerializationArray::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x00000000326678f0 9. ./build_docker/./src/Formats/NativeWriter.cpp:76: DB::NativeWriter::write(DB::Block const&) @ 0x000000003ada696b 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000003ac04275 11. ./contrib/llvm-project/libcxx/include/__mutex_base:253: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfbb15 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:37:08.043660 [ 4649 ] {51e899f7-e069-4cd2-9b7b-1a250837d951} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::1]:9000 -> [::1]:51994). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:158: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c63a0 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. DB::WriteBuffer::write(char const*, unsigned long) @ 0x00000000083dcce5 6. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:213: DB::SerializationNumber::serializeBinaryBulk(DB::IColumn const&, DB::WriteBuffer&, unsigned long, unsigned long) const @ 0x0000000032795a95 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1551: DB::SerializationArray::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x000000003266762d 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:63: DB::SerializationArray::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x00000000326678f0 9. ./build_docker/./src/Formats/NativeWriter.cpp:76: DB::NativeWriter::write(DB::Block const&) @ 0x000000003ada696b 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000003ac04275 11. ./contrib/llvm-project/libcxx/include/__mutex_base:253: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfbb15 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:37:08.044327 [ 4649 ] {51e899f7-e069-4cd2-9b7b-1a250837d951} TCPHandler: Client has gone away. 2025.10.23 23:37:08.816066 [ 4649 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:08.832457 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:09.144686 [ 4649 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:09.819664 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:09.935576 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:10.833595 [ 4649 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:10.905199 [ 4649 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:11.030890 [ 4649 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:11.969417 [ 4649 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:12.076953 [ 4649 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:12.270356 [ 4745 ] {d04ac13d-f21d-4940-990d-1a386971ce2f} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::1]:9000 -> [::1]:52104). (NETWORK_ERROR) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:52104) (comment: 02003_memory_limit_in_client.sh) (in query: SELECT arrayMap(x -> range(x), range(number)) FROM numbers(1000) -- { clientError MEMORY_LIMIT_EXCEEDED }), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:158: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c63a0 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. DB::WriteBuffer::write(char const*, unsigned long) @ 0x00000000083dcce5 6. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:213: DB::SerializationNumber::serializeBinaryBulk(DB::IColumn const&, DB::WriteBuffer&, unsigned long, unsigned long) const @ 0x0000000032795a95 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1551: DB::SerializationArray::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x000000003266762d 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:63: DB::SerializationArray::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x00000000326678f0 9. ./build_docker/./src/Formats/NativeWriter.cpp:76: DB::NativeWriter::write(DB::Block const&) @ 0x000000003ada696b 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000003ac04275 11. ./contrib/llvm-project/libcxx/include/__mutex_base:253: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfbb15 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:37:12.271991 [ 4745 ] {d04ac13d-f21d-4940-990d-1a386971ce2f} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::1]:9000 -> [::1]:52104). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:158: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c63a0 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. DB::WriteBuffer::write(char const*, unsigned long) @ 0x00000000083dcce5 6. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:213: DB::SerializationNumber::serializeBinaryBulk(DB::IColumn const&, DB::WriteBuffer&, unsigned long, unsigned long) const @ 0x0000000032795a95 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1551: DB::SerializationArray::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x000000003266762d 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:63: DB::SerializationArray::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x00000000326678f0 9. ./build_docker/./src/Formats/NativeWriter.cpp:76: DB::NativeWriter::write(DB::Block const&) @ 0x000000003ada696b 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000003ac04275 11. ./contrib/llvm-project/libcxx/include/__mutex_base:253: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfbb15 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:37:12.272430 [ 4745 ] {d04ac13d-f21d-4940-990d-1a386971ce2f} TCPHandler: Client has gone away. 2025.10.23 23:37:12.324373 [ 4649 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:12.992964 [ 4649 ] {c7f0d8b9-9ab2-49eb-8e95-7852cdcc4db9} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=778, jobs=742). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:52248) (comment: 02377_optimize_sorting_by_input_stream_properties_explain.sh) (in query: EXPLAIN PLAN actions=1, header=1, sorting=1 SELECT a, a+1 FROM optimize_sorting WHERE a+1 > 0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:37:12.994562 [ 4649 ] {c7f0d8b9-9ab2-49eb-8e95-7852cdcc4db9} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=778, jobs=742). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:37:13.020687 [ 4745 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:13.141796 [ 4745 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:13.796315 [ 4745 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:14.048747 [ 4745 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:14.200137 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:15.097029 [ 4745 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:15.243311 [ 4745 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:15.320791 [ 4745 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:16.120945 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:16.293546 [ 4745 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:16.666081 [ 4745 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:17.141488 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:17.321373 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:18.096395 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:18.162110 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:18.442883 [ 4745 ] {d8fbd5e8-492b-46bc-9aeb-f1a46fe9349a} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=778, jobs=742). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:40030) (comment: 02974_if_with_map.sql) (in query: select if(number % 2 = 0, materialize(map(1,2,3,4)), map(3,4,5,6)) from numbers(2);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:37:18.445649 [ 4745 ] {d8fbd5e8-492b-46bc-9aeb-f1a46fe9349a} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=778, jobs=742). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:37:18.476399 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:19.276819 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:19.445434 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:19.681037 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:20.342071 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:20.388362 [ 4745 ] {3a7fb2cb-9592-44e6-8bcd-7d8529f6c00b} executeQuery: Code: 524. DB::Exception: Trying to ALTER DROP column n3 which is referenced by materialized view ['01746_merge_tree_mv']. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:40084) (comment: 01746_forbid_drop_column_referenced_by_mv.sql) (in query: ALTER TABLE `01746_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3453: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039775cf1 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034866235 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003485e550 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:37:20.389439 [ 4745 ] {3a7fb2cb-9592-44e6-8bcd-7d8529f6c00b} TCPHandler: Code: 524. DB::Exception: Trying to ALTER DROP column n3 which is referenced by materialized view ['01746_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3453: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039775cf1 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034866235 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003485e550 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:37:20.505017 [ 4745 ] {6ecfaa11-0372-40d9-9b0f-b5bd4b35bf0c} executeQuery: Code: 524. DB::Exception: Trying to ALTER DROP column n2 which is referenced by materialized view ['01746_merge_tree_mv']. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:40084) (comment: 01746_forbid_drop_column_referenced_by_mv.sql) (in query: ALTER TABLE `01746_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3453: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039775cf1 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034866235 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003485e550 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:37:20.506723 [ 4745 ] {6ecfaa11-0372-40d9-9b0f-b5bd4b35bf0c} TCPHandler: Code: 524. DB::Exception: Trying to ALTER DROP column n2 which is referenced by materialized view ['01746_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3453: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039775cf1 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034866235 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003485e550 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:37:20.554860 [ 4694 ] {614e5922-8ee0-49e7-83f6-91424071cdf2} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.066534729 seconds, maximum: 1. (TIMEOUT_EXCEEDED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:40074) (comment: 01039_mergetree_exec_time.sql) (in query: select sum(sleep(0.1)) from tab settings max_block_size = 1, max_execution_time=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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x00000000322cd7ed 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x00000000322cb868 5. ./build_docker/./src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000003502621c 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 9. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 11. ? @ 0x00007f100c857ac3 12. ? @ 0x00007f100c8e9850 2025.10.23 23:37:20.561246 [ 4694 ] {614e5922-8ee0-49e7-83f6-91424071cdf2} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.066534729 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x00000000322cd7ed 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x00000000322cb868 5. ./build_docker/./src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000003502621c 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 9. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 11. ? @ 0x00007f100c857ac3 12. ? @ 0x00007f100c8e9850 2025.10.23 23:37:20.902802 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:21.040750 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:21.397918 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:21.776428 [ 4745 ] {7afc7206-f0fe-4309-8d1a-9b6cc6092930} executeQuery: Code: 524. DB::Exception: Trying to ALTER DROP column n1 which is referenced by materialized view ['01746_null_mv']. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:40084) (comment: 01746_forbid_drop_column_referenced_by_mv.sql) (in query: ALTER TABLE `01746_null` DROP COLUMN n1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Storages/StorageNull.cpp:58: DB::StorageNull::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003869ca65 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034866235 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003485e550 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:37:21.777701 [ 4745 ] {7afc7206-f0fe-4309-8d1a-9b6cc6092930} TCPHandler: Code: 524. DB::Exception: Trying to ALTER DROP column n1 which is referenced by materialized view ['01746_null_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Storages/StorageNull.cpp:58: DB::StorageNull::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003869ca65 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034866235 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003485e550 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:37:21.790288 [ 4745 ] {98413a27-67c4-4016-87c5-935ded3608f5} executeQuery: Code: 524. DB::Exception: Trying to ALTER DROP column n2 which is referenced by materialized view ['01746_null_mv']. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:40084) (comment: 01746_forbid_drop_column_referenced_by_mv.sql) (in query: ALTER TABLE `01746_null` 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Storages/StorageNull.cpp:58: DB::StorageNull::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003869ca65 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034866235 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003485e550 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:37:21.791287 [ 4745 ] {98413a27-67c4-4016-87c5-935ded3608f5} TCPHandler: Code: 524. DB::Exception: Trying to ALTER DROP column n2 which is referenced by materialized view ['01746_null_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Storages/StorageNull.cpp:58: DB::StorageNull::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003869ca65 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034866235 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003485e550 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:37:21.814785 [ 4745 ] {00b019f3-deef-4f52-924a-e8a5b92c412f} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Null. (NOT_IMPLEMENTED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:40084) (comment: 01746_forbid_drop_column_referenced_by_mv.sql) (in query: DROP TABLE `01746_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000002ffc5e67 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003493f2d5 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:37:21.815676 [ 4745 ] {00b019f3-deef-4f52-924a-e8a5b92c412f} TCPHandler: Code: 48. DB::Exception: Truncate is not supported by storage Null. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000002ffc5e67 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003493f2d5 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:37:22.001966 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:22.418947 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:22.420465 [ 3409 ] {} test_3.`02691_drop_column_replicated` (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.10.23 23:37:22.420537 [ 3417 ] {} test_3.rmt (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.10.23 23:37:22.420624 [ 3185 ] {} test_15.r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.10.23 23:37:22.421184 [ 3100 ] {} test_3.`02691_drop_column_replicated` (1045b1a8-f37f-4f75-892a-b44e770b298b): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_3/test/02691_drop_column/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:22.421196 [ 3432 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02725_start_stop_fetches_test_15/r/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:22.421356 [ 3473 ] {} test_3.rmt (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /test/02253/02253_empty_part_checksums_test_3/rmt/log. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x0000000030538e6c 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000003cbf3b60 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003cbea871 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000003a0439c9 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a04133c 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:50: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a03dd98 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003a06697f 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:22.421482 [ 3472 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000003cc8de51 3. ./src/Common/ZooKeeper/IKeeper.h:509: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003cd16a3e 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003cd2369f 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe6e6d 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe5f26 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe84e7 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe81ea 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000003a10064e 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000003889f11d 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f9f 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:22.421502 [ 3149 ] {} test_3.`02691_drop_column_replicated` (1045b1a8-f37f-4f75-892a-b44e770b298b): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000003cc8de51 3. ./src/Common/ZooKeeper/IKeeper.h:509: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003cd16a3e 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003cd2369f 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe6e6d 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe5f26 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe84e7 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe81ea 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000003a10064e 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000003889f11d 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f9f 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:22.422749 [ 3473 ] {} test_3.rmt (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000003cc8de51 3. ./src/Common/ZooKeeper/IKeeper.h:509: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003cd16a3e 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000003cd20792 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryExistsNoThrow(String const&, std::function) @ 0x000000003cbf3581 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003cbf26a1 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000003cbf3a70 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003cbea871 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000003a0439c9 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a04133c 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:50: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a03dd98 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003a06697f 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 15. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:23.098108 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:23.471668 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:23.697382 [ 4694 ] {} HTTPServerRequest: Got an HTTP request with no content length and no chunked/multipart encoding, it may be impossible to distinguish graceful EOF from abnormal connection loss 2025.10.23 23:37:24.132964 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:24.394842 [ 4694 ] {0e43f074-8cf8-498d-89dd-f001c466a1c0} executeQuery: Code: 57. DB::Exception: Table test_3.dict_data already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:40238) (comment: 01036_no_superfluous_dict_reload_on_create_database.sql) (in query: CREATE TABLE dict_data (key UInt64, 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:37:24.397743 [ 4694 ] {0e43f074-8cf8-498d-89dd-f001c466a1c0} TCPHandler: Code: 57. DB::Exception: Table test_3.dict_data already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:37:24.550657 [ 6961 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:25.044613 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:25.192177 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:25.631148 [ 6961 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:25.639517 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:26.261922 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:26.655241 [ 4694 ] {646a5c54-3053-4cb4-9fde-1a1ba6bed8e6} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:46508) (comment: 01080_check_for_error_incorrect_size_of_nested_column.sql) (in query: DROP DICTIONARY test_3.test_dict_01080), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349417ab 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:37:26.656965 [ 4694 ] {646a5c54-3053-4cb4-9fde-1a1ba6bed8e6} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349417ab 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:37:26.708713 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:26.756981 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:27.299337 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:27.780626 [ 6961 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:27.896686 [ 9453 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:28.059194 [ 9678 ] {3d4926a5-f303-424a-beb6-282fe096ca47} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42416) (comment: 02916_joinget_dependency.sh) (in query: DROP DATABASE IF EXISTS test_jmew3eys ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:37:28.061458 [ 9678 ] {3d4926a5-f303-424a-beb6-282fe096ca47} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:28.326743 [ 6961 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:28.840577 [ 6961 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:28.969465 [ 6961 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:29.405576 [ 9453 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:29.859258 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:29.928155 [ 3654 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {959c1387-6a29-41af-9a70-593d11e44aac::202510_1_52_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 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) @ 0x0000000039c89948 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000003999bfb7 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 @ 0x00000000399942f0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000039d15c04 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&) @ 0x0000000039d20399 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) @ 0x0000000039d1c606 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000396308a4 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x00000000396235dd 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000003963b3e0 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x00000000396504a0 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3c455d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:30.017708 [ 9453 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:30.505958 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:30.884660 [ 9453 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:31.044306 [ 4675 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:31.172553 [ 6961 ] {} TCPHandler: Code: 702. DB::Exception: Client info's client_name does not match: ClickHouse client not equal to Hacker client. (CLIENT_INFO_DOES_NOT_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x00000000083b42cd 4. ./build_docker/./src/Server/TCPHandler.cpp:171: DB::TCPHandler::receiveQuery() @ 0x000000003ac22738 5. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:37:31.173244 [ 6961 ] {} TCPHandler: Can't skip data packets after query failure. 2025.10.23 23:37:31.593980 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:31.946346 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:32.079517 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:32.643907 [ 9453 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:32.943109 [ 6961 ] {} TCPHandler: Code: 702. DB::Exception: Client info's version does not match: 20.13.0 (54443) not equal to 16.13.1 (54443). (CLIENT_INFO_DOES_NOT_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Server/TCPHandler.cpp:179: DB::TCPHandler::receiveQuery() @ 0x000000003ac22f15 5. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:37:32.943925 [ 6961 ] {} TCPHandler: Can't skip data packets after query failure. 2025.10.23 23:37:32.998132 [ 9453 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:33.181297 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:33.792782 [ 4675 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:34.035361 [ 4675 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:34.274587 [ 4675 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:34.869691 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:35.073469 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:35.357551 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:35.973616 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:36.107375 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:36.467265 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:36.888731 [ 2904 ] {ada0b87f-60c6-4c0d-9305-82ba8fbec21a} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:38528) (comment: 01244_optimize_distributed_group_by_sharding_key.sql) (in query: SELECT uniqExact(`__table1`.`number`) AS `countDistinct(number)` FROM `test_3`.`data_01247` AS `__table1` GROUP BY `__table1`.`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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:37:36.892739 [ 2904 ] {ada0b87f-60c6-4c0d-9305-82ba8fbec21a} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:37:36.956934 [ 4694 ] {669efe3e-ab82-4648-a345-c7945bf4b3a1} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:46852) (comment: 01244_optimize_distributed_group_by_sharding_key.sql) (in query: select count(DISTINCT number) from dist_01247 group by number;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002019af32 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000003a7e3e0c 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::Connection::receivePacket() @ 0x000000003a7ff61b 5. ./build_docker/./src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003a8ed7f8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000323566d1 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032355a26 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000032352f12 2025.10.23 23:37:36.960132 [ 4694 ] {669efe3e-ab82-4648-a345-c7945bf4b3a1} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 : 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002019af32 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000003a7e3e0c 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::Connection::receivePacket() @ 0x000000003a7ff61b 5. ./build_docker/./src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003a8ed7f8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000323566d1 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032355a26 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000032352f12 2025.10.23 23:37:37.058964 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:37.155602 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:37.495565 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:38.111370 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:38.207165 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:38.581848 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:39.158971 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:39.294395 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:39.649754 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:39.725966 [ 3933 ] {0d850d0c-1d50-424f-b4d9-f970801f4537} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:43926) (comment: 01007_r1r2_w_r2r1_deadlock.sh) (in query: SELECT x FROM a WHERE x IN (SELECT toUInt8(count()) FROM system.tables);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:37:39.731470 [ 3933 ] {0d850d0c-1d50-424f-b4d9-f970801f4537} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:37:40.243637 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:40.342776 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:40.454044 [ 4799 ] {d8c5cced-9a95-466b-a201-3fd623324a0b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:43918) (comment: 01007_r1r2_w_r2r1_deadlock.sh) (in query: SELECT x FROM b WHERE x IN (SELECT toUInt8(count()) FROM system.tables);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:37:40.459565 [ 4799 ] {d8c5cced-9a95-466b-a201-3fd623324a0b} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:37:40.485671 [ 3903 ] {57ed0060-4f66-4ab4-8e92-07d86c86c153} executeQuery: Code: 36. DB::Exception: Strict EXCEPT column transformer EXCEPT (id, value1) expects following column(s) : value1. In scope SELECT * EXCEPT STRICT (id, value1) FROM test_table. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:43958) (comment: 02343_analyzer_column_transformers_strict.sql) (in query: SELECT * EXCEPT STRICT (id, value1) 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception, std::__wrap_iter, char>, String>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity, std::__wrap_iter, char>>::type, std::type_identity::type>, char const*&&, String&&, fmt::v9::join_view, std::__wrap_iter, char>&&, String&&) @ 0x000000003350071f 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2320: DB::QueryAnalyzer::resolveMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d31fc 5. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344f323 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 8. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 26. ? @ 0x00007f100c857ac3 27. ? @ 0x00007f100c8e9850 2025.10.23 23:37:40.487036 [ 3903 ] {57ed0060-4f66-4ab4-8e92-07d86c86c153} TCPHandler: Code: 36. DB::Exception: Strict EXCEPT column transformer EXCEPT (id, value1) expects following column(s) : value1. In scope SELECT * EXCEPT STRICT (id, value1) FROM test_table. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception, std::__wrap_iter, char>, String>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity, std::__wrap_iter, char>>::type, std::type_identity::type>, char const*&&, String&&, fmt::v9::join_view, std::__wrap_iter, char>&&, String&&) @ 0x000000003350071f 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2320: DB::QueryAnalyzer::resolveMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d31fc 5. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344f323 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 8. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 26. ? @ 0x00007f100c857ac3 27. ? @ 0x00007f100c8e9850 2025.10.23 23:37:40.580082 [ 3903 ] {022127b1-06b7-4d03-b426-b9024591e126} executeQuery: Code: 36. DB::Exception: Strict REPLACE column transformer REPLACE (1 AS id, 2 AS value_1) expects following column(s) : value_1. In scope SELECT * REPLACE STRICT (1 AS id, 2 AS value_1) FROM test_table. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:43958) (comment: 02343_analyzer_column_transformers_strict.sql) (in query: SELECT * REPLACE STRICT (1 AS id, 2 AS value_1) 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception, std::__wrap_iter, char>, String>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity, std::__wrap_iter, char>>::type, std::type_identity::type>, char const*&&, String&&, fmt::v9::join_view, std::__wrap_iter, char>&&, String&&) @ 0x000000003350071f 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2320: DB::QueryAnalyzer::resolveMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d31fc 5. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344f323 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 8. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 26. ? @ 0x00007f100c857ac3 27. ? @ 0x00007f100c8e9850 2025.10.23 23:37:40.581454 [ 3903 ] {022127b1-06b7-4d03-b426-b9024591e126} TCPHandler: Code: 36. DB::Exception: Strict REPLACE column transformer REPLACE (1 AS id, 2 AS value_1) expects following column(s) : value_1. In scope SELECT * REPLACE STRICT (1 AS id, 2 AS value_1) FROM test_table. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception, std::__wrap_iter, char>, String>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity, std::__wrap_iter, char>>::type, std::type_identity::type>, char const*&&, String&&, fmt::v9::join_view, std::__wrap_iter, char>&&, String&&) @ 0x000000003350071f 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2320: DB::QueryAnalyzer::resolveMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d31fc 5. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344f323 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 8. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 26. ? @ 0x00007f100c857ac3 27. ? @ 0x00007f100c8e9850 2025.10.23 23:37:40.690858 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:41.301343 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:41.377326 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:41.757239 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:42.355990 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:42.440795 [ 4649 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:42.682316 [ 3418 ] {} test_3.`02691_drop_column_replicated` (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.10.23 23:37:42.682510 [ 3135 ] {} test_3.rmt (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.10.23 23:37:42.682577 [ 3182 ] {} test_15.r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.10.23 23:37:42.684057 [ 4675 ] {d885c791-33fe-4f2a-882e-e1457125d24c} executeQuery: Code: 999. Coordination::Exception: Coordination error: Connection loss, path /test/db/test_11/max_log_ptr. (KEEPER_EXCEPTION) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:46906) (comment: 01825_new_type_json_13.sh) (in query: CREATE TABLE t_json_13 (`obj` JSON) ENGINE = MergeTree ORDER BY tuple() SETTINGS replace_long_file_name_to_hash = 1, index_granularity = 15042, min_bytes_for_wide_part = 951290679, ratio_of_defaults_for_sparse_serialization = 1., max_file_name_length = 118, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 125512230, compact_parts_max_granules_to_buffer = 76, compact_parts_merge_max_bytes_to_prefetch_part = 15097644, merge_max_block_size = 6811, old_parts_lifetime = 391., prefer_fetch_merged_part_size_threshold = 6972600329, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 20589184, concurrent_part_removal_threshold = 79, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 54126, primary_key_compress_block_size = 25712), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x0000000030538e6c 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000003cbf6898 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003cbf5ab3 6. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ad5036 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a52a3c 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfab2 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:37:42.686396 [ 4675 ] {d885c791-33fe-4f2a-882e-e1457125d24c} TCPHandler: Code: 999. Coordination::Exception: Coordination error: Connection loss, path /test/db/test_11/max_log_ptr. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x0000000030538e6c 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000003cbf6898 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003cbf5ab3 6. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ad5036 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a52a3c 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfab2 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:37:42.785830 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:43.136761 [ 4694 ] {aebe4d93-093f-49a4-9d12-27daef6f85ad} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44030) (comment: 01007_r1r2_w_r2r1_deadlock.sh) (in query: SELECT x FROM b WHERE x IN (SELECT toUInt8(count()) FROM system.tables);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:37:43.140222 [ 4694 ] {aebe4d93-093f-49a4-9d12-27daef6f85ad} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:37:43.285314 [ 3433 ] {} test_3.rmt (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /test/02253/02253_empty_part_checksums_test_3/rmt/blocks. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x0000000030538e6c 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe8649 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000003cbe7761 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x000000003a061e9e 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x000000003a04fe19 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a041419 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:50: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a03dd98 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003a06697f 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:43.286595 [ 3433 ] {} test_3.rmt (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000003cc8de51 3. ./src/Common/ZooKeeper/IKeeper.h:509: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003cd16a3e 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000003cd20792 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryExistsNoThrow(String const&, std::function) @ 0x000000003cbf3581 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003cbf26a1 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000003cbf3a70 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003cbea871 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000003a0439c9 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a04133c 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:50: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a03dd98 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003a06697f 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 15. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:43.392407 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:43.426153 [ 4841 ] {9ee4d068-fc70-48c2-8920-f8467c94edf1} executeQuery: Code: 60. DB::Exception: Table test_11.t_json_13 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44112) (comment: 01825_new_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b14381 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:433: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000003399fc33 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:957: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339b4ac1 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000034b9ec4f 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000034bb99c8 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:43.428119 [ 4841 ] {9ee4d068-fc70-48c2-8920-f8467c94edf1} TCPHandler: Code: 60. DB::Exception: Table test_11.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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b14381 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:433: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000003399fc33 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:957: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339b4ac1 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000034b9ec4f 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000034bb99c8 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:43.470053 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:43.755125 [ 4694 ] {476c3542-d189-4621-8c16-248b07d6c3fd} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44132) (comment: 01007_r1r2_w_r2r1_deadlock.sh) (in query: SELECT x FROM b WHERE x IN (SELECT toUInt8(count()) FROM system.tables);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:37:43.759078 [ 4694 ] {476c3542-d189-4621-8c16-248b07d6c3fd} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:37:43.909682 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:44.180036 [ 4694 ] {9affd399-ee8b-43a8-a57d-6f45573ac7b2} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't_json_13' in scope SELECT DISTINCT arrayJoin(JSONAllPathsWithTypes(obj)) AS path FROM t_json_13 ORDER BY path ASC. (UNKNOWN_TABLE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44150) (comment: 01825_new_type_json_13.sh) (in query: SELECT DISTINCT arrayJoin(JSONAllPathsWithTypes(obj)) as path FROM t_json_13 order by path;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa0996d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334eae8a 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003343676d 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 2025.10.23 23:37:44.182056 [ 4694 ] {9affd399-ee8b-43a8-a57d-6f45573ac7b2} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't_json_13' in scope SELECT DISTINCT arrayJoin(JSONAllPathsWithTypes(obj)) AS path FROM t_json_13 ORDER BY path 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa0996d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334eae8a 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003343676d 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 2025.10.23 23:37:44.443542 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:44.516099 [ 4649 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:44.719655 [ 7759 ] {7d0938c7-6304-48a8-9e8e-d3688d8f485f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:43992) (comment: 01007_r1r2_w_r2r1_deadlock.sh) (in query: SELECT x FROM a WHERE x IN (SELECT toUInt8(count()) FROM system.tables);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:37:44.723442 [ 7759 ] {7d0938c7-6304-48a8-9e8e-d3688d8f485f} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:37:44.765177 [ 9340 ] {} ZooKeeperClient: Code: 999. Coordination::Exception: Session expired (fault injected on recv). (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000003a21d8b1 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEES0_NS_5ErrorEOS5_ @ 0x000000003cd2cd64 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1660: Coordination::ZooKeeper::maybeInjectRecvFault() @ 0x000000003cd156a2 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveEvent() @ 0x000000003cd1207c 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveThread() @ 0x000000003cd109b9 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl> const&, zkutil::ZooKeeperArgs const&, std::shared_ptr)::$_1>(Coordination::ZooKeeper::ZooKeeper(std::vector> const&, zkutil::ZooKeeperArgs const&, std::shared_ptr)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003cd2940f 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:44.765916 [ 3339 ] {} test_3.`02691_drop_column_replicated` (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.10.23 23:37:44.765993 [ 3075 ] {} test_3.rmt (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.10.23 23:37:44.766152 [ 3085 ] {} test_15.r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.10.23 23:37:44.766618 [ 3421 ] {} test_3.rmt (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /test/02253/02253_empty_part_checksums_test_3/rmt/log. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x0000000030538e6c 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000003cbf3b60 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003cbea871 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000003a0439c9 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a04133c 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:50: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a03dd98 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003a06697f 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:44.766762 [ 3371 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000003cc8de51 3. ./src/Common/ZooKeeper/IKeeper.h:509: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003cd16a3e 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1383: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x000000003cd1a472 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x000000003cbf5306 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:610: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x000000003cbf42db 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000003cbf676b 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003cbf5ab3 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x000000003a0eb80c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889e7df 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:44.767927 [ 3421 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000003cc8de51 3. ./src/Common/ZooKeeper/IKeeper.h:509: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003cd16a3e 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003cd2369f 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe6e6d 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe5f26 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe84e7 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe81ea 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000003a10064e 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000003889f11d 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f9f 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:44.913166 [ 7759 ] {be490738-8290-4cb7-909e-863b022a5975} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't_json_13' in scope SELECT DISTINCT arrayJoin(JSONAllPathsWithTypes(arrayJoin(obj.key1.`:\`Array(JSON)\``))) AS path FROM t_json_13 ORDER BY path ASC. (UNKNOWN_TABLE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44172) (comment: 01825_new_type_json_13.sh) (in query: SELECT DISTINCT arrayJoin(JSONAllPathsWithTypes(arrayJoin(obj.key1[]))) as path FROM t_json_13 order by path;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa0996d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334eae8a 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003343676d 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 2025.10.23 23:37:44.915817 [ 7759 ] {be490738-8290-4cb7-909e-863b022a5975} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't_json_13' in scope SELECT DISTINCT arrayJoin(JSONAllPathsWithTypes(arrayJoin(obj.key1.`:\`Array(JSON)\``))) AS path FROM t_json_13 ORDER BY path 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa0996d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334eae8a 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003343676d 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 2025.10.23 23:37:44.971818 [ 4649 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:45.521308 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:45.563580 [ 4649 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:45.629681 [ 9678 ] {29ccc29a-ce5b-4554-a537-c636896301d3} 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.10542.altinitytest (altinity build)) (from [::1]:44438) (comment: 01825_new_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa0996d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334eae8a 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003343676d 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 2025.10.23 23:37:45.631813 [ 9678 ] {29ccc29a-ce5b-4554-a537-c636896301d3} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa0996d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334eae8a 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003343676d 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 2025.10.23 23:37:46.119820 [ 9453 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:46.368467 [ 9678 ] {a6e37392-f3d0-4d80-9359-fd13e4363e8e} 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.10542.altinitytest (altinity build)) (from [::1]:44468) (comment: 01825_new_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa0996d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334eae8a 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003343676d 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 2025.10.23 23:37:46.370779 [ 9678 ] {a6e37392-f3d0-4d80-9359-fd13e4363e8e} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa0996d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334eae8a 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003343676d 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 2025.10.23 23:37:46.609094 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:46.637812 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:47.084836 [ 9678 ] {724a147f-e5e2-4264-a054-fd3a07b04e7a} executeQuery: Code: 60. DB::Exception: Table test_11.t_json_13 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44496) (comment: 01825_new_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b14381 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:433: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000003399fc33 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339b5107 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003493bddb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:37:47.086762 [ 9678 ] {724a147f-e5e2-4264-a054-fd3a07b04e7a} TCPHandler: Code: 60. DB::Exception: Table test_11.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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b14381 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:433: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000003399fc33 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339b5107 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003493bddb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:37:47.186260 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:47.676031 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:47.714153 [ 9453 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:48.249740 [ 9453 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:48.382175 [ 9678 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:44512, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x00000000204bfd30 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x00000000204c0cc1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a8112cd 6. DB::ReadBuffer::next() @ 0x00000000095b468f 7. ./src/IO/VarInt.h:95: void DB::varint_impl::readVarUInt(unsigned long&, DB::ReadBuffer&) @ 0x0000000020183948 8. ./src/IO/ReadHelpers.h:143: DB::readStringBinary(String&, DB::ReadBuffer&, unsigned long) @ 0x00000000201f6132 9. ./build_docker/./src/Server/TCPHandler.cpp:1653: DB::TCPHandler::receiveAddendum() @ 0x000000003abf3573 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd5c38 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:48.733173 [ 9453 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:48.812893 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:48.997836 [ 4841 ] {cd45b930-7bfd-4099-b117-d551ed70f045} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::1]:9000 -> [::1]:44162). (NETWORK_ERROR) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44162) (comment: 01007_r1r2_w_r2r1_deadlock.sh) (in query: SELECT x FROM b WHERE x IN (SELECT toUInt8(count()) FROM system.tables);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:158: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c63a0 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileInfo(DB::ProfileInfo const&) @ 0x000000003ac0e495 6. ./build_docker/./src/Server/TCPHandler.cpp:1165: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfc070 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 2025.10.23 23:37:48.997836 [ 3895 ] {a29bb2d1-b86d-4367-aae5-07a55cf95cb5} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::1]:9000 -> [::1]:44400). (NETWORK_ERROR) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44400) (comment: 01007_r1r2_w_r2r1_deadlock.sh) (in query: SELECT x FROM a WHERE x IN (SELECT toUInt8(count()) FROM system.tables);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:158: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c63a0 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileInfo(DB::ProfileInfo const&) @ 0x000000003ac0e495 6. ./build_docker/./src/Server/TCPHandler.cpp:1165: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfc070 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 2025.10.23 23:37:49.002243 [ 4841 ] {cd45b930-7bfd-4099-b117-d551ed70f045} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:44162). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c6938 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000003ac2dd9a 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x000000003abff96a 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9aa8 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:49.002243 [ 3895 ] {a29bb2d1-b86d-4367-aae5-07a55cf95cb5} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:44400). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c6938 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000003ac2dd9a 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x000000003abff96a 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9aa8 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:49.002662 [ 3895 ] {a29bb2d1-b86d-4367-aae5-07a55cf95cb5} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::1]:9000 -> [::1]:44400). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:158: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c63a0 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileInfo(DB::ProfileInfo const&) @ 0x000000003ac0e495 6. ./build_docker/./src/Server/TCPHandler.cpp:1165: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfc070 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 2025.10.23 23:37:49.002659 [ 4841 ] {cd45b930-7bfd-4099-b117-d551ed70f045} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::1]:9000 -> [::1]:44162). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:158: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c63a0 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileInfo(DB::ProfileInfo const&) @ 0x000000003ac0e495 6. ./build_docker/./src/Server/TCPHandler.cpp:1165: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfc070 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 2025.10.23 23:37:49.003321 [ 4841 ] {cd45b930-7bfd-4099-b117-d551ed70f045} TCPHandler: Client has gone away. 2025.10.23 23:37:49.003321 [ 3895 ] {a29bb2d1-b86d-4367-aae5-07a55cf95cb5} TCPHandler: Client has gone away. 2025.10.23 23:37:49.313926 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:49.840075 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:49.904766 [ 9453 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:50.386761 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:50.925262 [ 9453 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:50.940914 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:51.189275 [ 7565 ] {1996ef31-eefc-421c-94e8-327183287a67} DB::ConcurrentHashJoin::ConcurrentHashJoin(ContextPtr, std::shared_ptr, size_t, const Block &, const StatsCollectingParams &, bool): 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202dea34 6. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:0: DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, std::shared_ptr, unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool) @ 0x0000000034775418 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr&, std::shared_ptr&, DB::SettingFieldMaxThreads const&, DB::Block const&, DB::StatsCollectingParams&, void>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::SettingFieldMaxThreads const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x0000000034df93df 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000034debf55 9. ./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&) @ 0x0000000034d95d85 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d6a797 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0b8de 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cfd8b2 13. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d1d378 14. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cfd8b2 15. ./src/Planner/Planner.h:56: DB::InterpreterSelectQueryAnalyzer::extractQueryPlan() && @ 0x0000000034cf61b2 16. ./build_docker/./src/Processors/QueryPlan/DistributedCreateLocalPlan.cpp:45: DB::createLocalPlan(std::shared_ptr const&, DB::Block const&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long, bool) @ 0x000000003bdfd5fc 17. ./build_docker/./src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:161: DB::ClusterProxy::SelectStreamFactory::createForShardImpl(DB::Cluster::ShardInfo const&, std::shared_ptr const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>, bool)::$_0::operator()() const @ 0x0000000036f92d9c 18. ./build_docker/./src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:234: DB::ClusterProxy::SelectStreamFactory::createForShardImpl(DB::Cluster::ShardInfo const&, std::shared_ptr const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>, bool) @ 0x0000000036f8e5fe 19. ./build_docker/./src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:0: DB::ClusterProxy::SelectStreamFactory::createForShard(DB::Cluster::ShardInfo const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>) @ 0x0000000036f93901 20. ./build_docker/./src/Interpreters/ClusterProxy/executeQuery.cpp:0: DB::ClusterProxy::executeQuery(DB::QueryPlan&, DB::Block const&, DB::QueryProcessingStage::Enum, DB::StorageID const&, std::shared_ptr const&, DB::ClusterProxy::SelectStreamFactory&, std::shared_ptr, std::shared_ptr, DB::SelectQueryInfo const&, std::shared_ptr const&, String const&, DB::DistributedSettings const&, std::function (unsigned long)>, bool) @ 0x0000000036f59aff 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038285416 22. ./src/Processors/QueryPlan/QueryPlan.h:53: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000034d80c82 23. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1777: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d67094 24. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0b8de 25. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cfd8b2 26. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034cf6172 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5bf1 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:51.293833 [ 7565 ] {1996ef31-eefc-421c-94e8-327183287a67} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44536) (comment: 01103_distributed_product_mode_local_column_renames.sql) (in query: select d0.id from t1_distr d0 where d0.id in ( select d1.id from t1_distr as d1 inner join t2_distr as d2 on d1.id = d2.id where d1.id > 0 order by d1.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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202dea34 6. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:0: DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, std::shared_ptr, unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool) @ 0x0000000034775418 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr&, std::shared_ptr&, DB::SettingFieldMaxThreads const&, DB::Block const&, DB::StatsCollectingParams&, void>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::SettingFieldMaxThreads const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x0000000034df93df 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000034debf55 9. ./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&) @ 0x0000000034d95d85 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d6a797 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0b8de 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cfd8b2 13. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d1d378 14. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cfd8b2 15. ./src/Planner/Planner.h:56: DB::InterpreterSelectQueryAnalyzer::extractQueryPlan() && @ 0x0000000034cf61b2 16. ./build_docker/./src/Processors/QueryPlan/DistributedCreateLocalPlan.cpp:45: DB::createLocalPlan(std::shared_ptr const&, DB::Block const&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long, bool) @ 0x000000003bdfd5fc 17. ./build_docker/./src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:161: DB::ClusterProxy::SelectStreamFactory::createForShardImpl(DB::Cluster::ShardInfo const&, std::shared_ptr const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>, bool)::$_0::operator()() const @ 0x0000000036f92d9c 18. ./build_docker/./src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:234: DB::ClusterProxy::SelectStreamFactory::createForShardImpl(DB::Cluster::ShardInfo const&, std::shared_ptr const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>, bool) @ 0x0000000036f8e5fe 19. ./build_docker/./src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:0: DB::ClusterProxy::SelectStreamFactory::createForShard(DB::Cluster::ShardInfo const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>) @ 0x0000000036f93901 20. ./build_docker/./src/Interpreters/ClusterProxy/executeQuery.cpp:0: DB::ClusterProxy::executeQuery(DB::QueryPlan&, DB::Block const&, DB::QueryProcessingStage::Enum, DB::StorageID const&, std::shared_ptr const&, DB::ClusterProxy::SelectStreamFactory&, std::shared_ptr, std::shared_ptr, DB::SelectQueryInfo const&, std::shared_ptr const&, String const&, DB::DistributedSettings const&, std::function (unsigned long)>, bool) @ 0x0000000036f59aff 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038285416 22. ./src/Processors/QueryPlan/QueryPlan.h:53: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000034d80c82 23. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1777: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d67094 24. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0b8de 25. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cfd8b2 26. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034cf6172 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5bf1 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 2025.10.23 23:37:51.296572 [ 7565 ] {1996ef31-eefc-421c-94e8-327183287a67} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202dea34 6. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:0: DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, std::shared_ptr, unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool) @ 0x0000000034775418 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr&, std::shared_ptr&, DB::SettingFieldMaxThreads const&, DB::Block const&, DB::StatsCollectingParams&, void>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::SettingFieldMaxThreads const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x0000000034df93df 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000034debf55 9. ./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&) @ 0x0000000034d95d85 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d6a797 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0b8de 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cfd8b2 13. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d1d378 14. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cfd8b2 15. ./src/Planner/Planner.h:56: DB::InterpreterSelectQueryAnalyzer::extractQueryPlan() && @ 0x0000000034cf61b2 16. ./build_docker/./src/Processors/QueryPlan/DistributedCreateLocalPlan.cpp:45: DB::createLocalPlan(std::shared_ptr const&, DB::Block const&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long, bool) @ 0x000000003bdfd5fc 17. ./build_docker/./src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:161: DB::ClusterProxy::SelectStreamFactory::createForShardImpl(DB::Cluster::ShardInfo const&, std::shared_ptr const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>, bool)::$_0::operator()() const @ 0x0000000036f92d9c 18. ./build_docker/./src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:234: DB::ClusterProxy::SelectStreamFactory::createForShardImpl(DB::Cluster::ShardInfo const&, std::shared_ptr const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>, bool) @ 0x0000000036f8e5fe 19. ./build_docker/./src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:0: DB::ClusterProxy::SelectStreamFactory::createForShard(DB::Cluster::ShardInfo const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>) @ 0x0000000036f93901 20. ./build_docker/./src/Interpreters/ClusterProxy/executeQuery.cpp:0: DB::ClusterProxy::executeQuery(DB::QueryPlan&, DB::Block const&, DB::QueryProcessingStage::Enum, DB::StorageID const&, std::shared_ptr const&, DB::ClusterProxy::SelectStreamFactory&, std::shared_ptr, std::shared_ptr, DB::SelectQueryInfo const&, std::shared_ptr const&, String const&, DB::DistributedSettings const&, std::function (unsigned long)>, bool) @ 0x0000000036f59aff 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038285416 22. ./src/Processors/QueryPlan/QueryPlan.h:53: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000034d80c82 23. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1777: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d67094 24. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0b8de 25. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cfd8b2 26. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034cf6172 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5bf1 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 2025.10.23 23:37:51.447667 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:51.966100 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:52.010336 [ 9453 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:52.517813 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:53.010707 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:53.052788 [ 4675 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:53.130870 [ 7565 ] {64d421c7-fa50-48d8-bfc7-7baf0b40e26d} DatabaseReplicated (test_11): It's not recommended to explicitly specify zookeeper_path and replica_name in ReplicatedMergeTree arguments 2025.10.23 23:37:53.132279 [ 7565 ] {64d421c7-fa50-48d8-bfc7-7baf0b40e26d} executeQuery: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44726) (comment: 02771_parallel_replicas_analyzer.sql) (in query: CREATE TABLE join_inner_table__fuzz_146_replicated (`id` UUID, `key` String, `number` Int64, `value1` String, `value2` String, `time` Nullable(Int64)) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/join_inner_table__fuzz_146_replicated', '{replica}') ORDER BY (id, number, key) SETTINGS index_granularity = 8192, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 0, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 444360365, compact_parts_max_granules_to_buffer = 91, compact_parts_merge_max_bytes_to_prefetch_part = 18571605, merge_max_block_size = 131, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 11870998, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 71355, primary_key_compress_block_size = 35127), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000032a4a38c 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000032a4fcff 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a51799 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfab2 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:53.134607 [ 7565 ] {64d421c7-fa50-48d8-bfc7-7baf0b40e26d} TCPHandler: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000032a4a38c 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000032a4fcff 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a51799 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfab2 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:53.580654 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:54.109294 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:54.124030 [ 4675 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:54.293033 [ 9453 ] {c3421385-6d74-48ab-a32b-04cf71877619} DynamicQueryHandler: Code: 69. DB::Exception: Chunk size exceeded the limit (max size: 107374182400). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000b46526a 4. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:36: DB::HTTPChunkedReadBuffer::readChunkHeader() @ 0x000000003ac6185e 5. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:63: DB::HTTPChunkedReadBuffer::nextImpl() @ 0x000000003ac61e90 6. DB::ReadBuffer::next() @ 0x00000000095b468f 7. ./build_docker/./src/IO/PeekableReadBuffer.cpp:0: DB::PeekableReadBuffer::nextImpl() @ 0x0000000020200498 8. DB::ReadBuffer::next() @ 0x00000000095b468f 9. ./build_docker/./src/Server/HTTP/HTMLForm.cpp:254: DB::HTMLForm::MultipartReadBuffer::skipToNextBoundary() @ 0x000000003ac52dcd 10. ./build_docker/./src/Server/HTTP/HTMLForm.cpp:0: DB::HTMLForm::readMultipart(DB::ReadBuffer&, DB::HTMLForm::PartHandler&) @ 0x000000003ac50d41 11. ./build_docker/./src/Server/HTTP/HTMLForm.cpp:0: DB::HTMLForm::load(Poco::Net::HTTPRequest const&, DB::ReadBuffer&, DB::HTMLForm::PartHandler&) @ 0x000000003ac4dca1 12. ./contrib/llvm-project/libcxx/include/string:1624: DB::DynamicQueryHandler::getQuery(DB::HTTPServerRequest&, DB::HTMLForm&, std::shared_ptr) @ 0x000000003aa3db41 13. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa26e72 14. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 21. ? @ 0x00007f100c857ac3 22. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:54.671555 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:55.132030 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:55.146474 [ 3393 ] {} test_3.`02691_drop_column_replicated` (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.10.23 23:37:55.146582 [ 3326 ] {} test_3.rmt (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.10.23 23:37:55.146702 [ 3111 ] {} test_15.r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.10.23 23:37:55.147135 [ 3277 ] {} test_3.rmt (1c58b3d3-3aa3-4fc2-81b4-6ea1ac046ae6): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/02253/02253_empty_part_checksums_test_3/rmt/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:55.147146 [ 3487 ] {} test_3.`02691_drop_column_replicated` (1045b1a8-f37f-4f75-892a-b44e770b298b): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_3/test/02691_drop_column/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:55.147334 [ 3236 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000003cc8de51 3. ./src/Common/ZooKeeper/IKeeper.h:509: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003cd16a3e 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003cd2369f 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe6e6d 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe5f26 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe84e7 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe81ea 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000003a10064e 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000003889f11d 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f9f 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:55.147355 [ 3384 ] {} test_3.rmt (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Session expired (fault injected on send). (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000003a21d8b1 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEES0_NS_5ErrorEOS5_ @ 0x000000003cd2cd64 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1654: Coordination::ZooKeeper::maybeInjectSendFault() @ 0x000000003cd17122 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003cd165e8 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003cd2369f 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe6e6d 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe5f26 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe84e7 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000003cbe7761 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x000000003a061e9e 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x000000003a04fe19 13. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:165: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a04156e 14. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:50: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a03dd98 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003a06697f 16. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 18. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 21. ? @ 0x00007f100c857ac3 22. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:55.147608 [ 3273 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000003cc8de51 3. ./src/Common/ZooKeeper/IKeeper.h:509: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003cd16a3e 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1383: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x000000003cd1a472 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x000000003cbf5306 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:610: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x000000003cbf42db 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000003cbf676b 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003cbf5ab3 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x000000003a0eb80c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889e7df 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:55.147607 [ 3083 ] {} test_3.`02691_drop_column_replicated` (1045b1a8-f37f-4f75-892a-b44e770b298b): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000003cc8de51 3. ./src/Common/ZooKeeper/IKeeper.h:509: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003cd16a3e 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003cd2369f 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe6e6d 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe5f26 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe84e7 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe81ea 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000003a10064e 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000003889f11d 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f9f 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:55.148006 [ 3441 ] {} test_3.rmt (1c58b3d3-3aa3-4fc2-81b4-6ea1ac046ae6): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000003cc8de51 3. ./src/Common/ZooKeeper/IKeeper.h:509: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003cd16a3e 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003cd2369f 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe6e6d 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe5f26 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe84e7 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe81ea 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000003a10064e 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000003889f11d 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f9f 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:55.351215 [ 9453 ] {c3421385-6d74-48ab-a32b-04cf71877619} DynamicQueryHandler: Cannot read remaining request body during exception handling: Code: 408. DB::Exception: Unexpected data instead of HTTP chunk header. (BAD_REQUEST_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:0: DB::HTTPChunkedReadBuffer::readChunkHeader() @ 0x000000003ac61c0e 5. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:63: DB::HTTPChunkedReadBuffer::nextImpl() @ 0x000000003ac61e90 6. DB::ReadBuffer::next() @ 0x00000000095b468f 7. ./build_docker/./src/Server/HTTP/sendExceptionToHTTPClient.cpp:65: DB::setHTTPResponseStatusAndHeadersForException(int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::WriteBufferFromHTTPServerResponse*, std::shared_ptr) @ 0x000000003ac7aa02 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::HTTPHandler::trySendExceptionToClient(String const&, int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x000000003aa2f560 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa3830a 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:55.408038 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:55.652924 [ 7565 ] {2e5b9679-0029-4d1c-8fa6-3e0a0425785e} ConnectionPoolWithFailover: Connection failed at try â„–1, reason: Code: 210. DB::NetException: Net Exception: Network is unreachable (255.255.255.255:9000). (NETWORK_ERROR) (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:55.770099 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:56.167528 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:56.505677 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:56.506287 [ 9453 ] {c3421385-6d74-48ab-a32b-04cf71877619} DynamicQueryHandler: Cannot send exception to client: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:57502). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:105: DB::WriteBufferFromPocoSocket::socketSendBytes(char const*, unsigned long) @ 0x00000000204c471f 4. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:99: DB::WriteBufferFromHTTPServerResponse::finishSendHeaders() @ 0x000000003ac6c5e1 5. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:0: DB::WriteBufferFromHTTPServerResponse::nextImpl() @ 0x000000003ac6cd34 6. ./src/IO/WriteBuffer.h:66: DB::HTTPHandler::trySendExceptionToClient(String const&, int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x000000003aa2ff2a 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa3830a 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:56.839089 [ 9453 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:56.855680 [ 7565 ] {2e5b9679-0029-4d1c-8fa6-3e0a0425785e} executeQuery: Code: 519. DB::NetException: All attempts to get table structure failed. Log: . (NO_REMOTE_SHARD_AVAILABLE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44352) (comment: 01956_skip_unavailable_shards_excessive_attempts.sh) (in query: select * from remote('255.255.255.255', system.one) settings use_hedged_requests=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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x0000000038d57a6a 3. ./build_docker/./src/Storages/getStructureOfRemoteTable.cpp:170: DB::getStructureOfRemoteTable(DB::Cluster const&, DB::StorageID const&, std::shared_ptr, std::shared_ptr const&) @ 0x0000000038d50cb8 4. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::TableFunctionRemote::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002fde1389 5. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:0: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002fddf87a 6. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f70b3 7. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000003374cff2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4838: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003345fff3 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334edd21 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436960 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 2025.10.23 23:37:56.858859 [ 7565 ] {2e5b9679-0029-4d1c-8fa6-3e0a0425785e} TCPHandler: Code: 519. DB::NetException: All attempts to get table structure failed. Log: . (NO_REMOTE_SHARD_AVAILABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x0000000038d57a6a 3. ./build_docker/./src/Storages/getStructureOfRemoteTable.cpp:170: DB::getStructureOfRemoteTable(DB::Cluster const&, DB::StorageID const&, std::shared_ptr, std::shared_ptr const&) @ 0x0000000038d50cb8 4. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::TableFunctionRemote::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002fde1389 5. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:0: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002fddf87a 6. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f70b3 7. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000003374cff2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4838: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003345fff3 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334edd21 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436960 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 2025.10.23 23:37:57.234065 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:57.575224 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:57.909525 [ 3709 ] {85c849ba-7604-4c34-aa3b-34be2a84f4f3} ConnectionPoolWithFailover: Connection failed at try â„–1, reason: Code: 210. DB::NetException: Net Exception: Network is unreachable (255.255.255.255:9000). (NETWORK_ERROR) (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:57.911874 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:58.277269 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:58.631044 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:58.692323 [ 9453 ] {8493e77e-8873-4244-a3fd-ed06b919d925} ConnectionPoolWithFailover: Connection failed at try â„–1, reason: Code: 210. DB::NetException: Net Exception: Network is unreachable (255.255.255.255:9000). (NETWORK_ERROR) (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:58.881304 [ 13707 ] {8493e77e-8873-4244-a3fd-ed06b919d925} ConnectionPoolWithFailover: Connection failed at try â„–1, reason: Code: 210. DB::NetException: Net Exception: Network is unreachable (255.255.255.255:9000). (NETWORK_ERROR) (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:58.970614 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:59.345201 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:37:59.696692 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:00.011128 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:00.385186 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:00.831904 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:01.074107 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:01.420112 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:01.907437 [ 4799 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:02.123167 [ 4799 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:02.451263 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:02.950398 [ 4799 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:03.192652 [ 4799 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:03.473382 [ 4799 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:04.020378 [ 4799 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:04.066195 [ 6965 ] {6c1e8747-f168-4452-88c9-9af973cd3b5f} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:51830) (comment: 02998_attach_partition_not_allowed_if_structure_differs_due_to_materialized_column.sql) (in query: DROP DATABASE IF EXISTS test_p0f6w7qk ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:38:04.068228 [ 6965 ] {6c1e8747-f168-4452-88c9-9af973cd3b5f} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:04.263892 [ 4799 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:04.533573 [ 4799 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:05.015031 [ 7565 ] {84ab941b-8a70-45fa-a9e3-12274d2fe465} executeQuery: Code: 36. DB::Exception: Cannot sleep infinite, very large or negative amount of time (not implemented). (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44614) (comment: 01655_sleep_infinite_float.sql) (in query: SELECT sleep(nan);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. DB::FunctionSleep<(DB::FunctionSleepVariant)0>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0ba11d 5. DB::FunctionSleep<(DB::FunctionSleepVariant)0>::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b8d74 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000003324d830 11. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000033248983 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003b82b8f7 13. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:0: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000003bdff695 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000034d2837e 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d111cc 16. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cfd8b2 17. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034cf6172 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5bf1 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 27. ? @ 0x00007f100c857ac3 28. ? @ 0x00007f100c8e9850 2025.10.23 23:38:05.016350 [ 7565 ] {84ab941b-8a70-45fa-a9e3-12274d2fe465} TCPHandler: Code: 36. DB::Exception: Cannot sleep infinite, very large or negative amount of time (not implemented). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. DB::FunctionSleep<(DB::FunctionSleepVariant)0>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0ba11d 5. DB::FunctionSleep<(DB::FunctionSleepVariant)0>::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b8d74 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000003324d830 11. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000033248983 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003b82b8f7 13. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:0: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000003bdff695 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000034d2837e 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d111cc 16. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cfd8b2 17. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034cf6172 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5bf1 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 27. ? @ 0x00007f100c857ac3 28. ? @ 0x00007f100c8e9850 2025.10.23 23:38:05.108541 [ 3903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:05.135820 [ 9557 ] {ebab6499-d0df-44dc-a262-b18bf558050e} executeQuery: Code: 43. DB::Exception: Third argument of function dictHas must be tuple when dictionary is complex and key contains more than 1 attribute.Actual type String.: In scope SELECT dictHas('01280_db.ssd_dict', 'a', tuple('1')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44624) (comment: 01280_ssd_complex_key_dictionary.sh) (in query: SELECT dictHas('01280_db.ssd_dict', 'a', tuple('1'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. DB::FunctionDictHas::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000096dde80 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 2025.10.23 23:38:05.137244 [ 9557 ] {ebab6499-d0df-44dc-a262-b18bf558050e} TCPHandler: Code: 43. DB::Exception: Third argument of function dictHas must be tuple when dictionary is complex and key contains more than 1 attribute.Actual type String.: In scope SELECT dictHas('01280_db.ssd_dict', 'a', tuple('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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. DB::FunctionDictHas::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000096dde80 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 2025.10.23 23:38:05.219171 [ 7565 ] {0882d2ae-e57b-4205-ace7-9abbd2fd9897} executeQuery: Code: 36. DB::Exception: Cannot sleep infinite, very large or negative amount of time (not implemented). (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44614) (comment: 01655_sleep_infinite_float.sql) (in query: SELECT sleep(inf);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. DB::FunctionSleep<(DB::FunctionSleepVariant)0>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0ba11d 5. DB::FunctionSleep<(DB::FunctionSleepVariant)0>::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b8d74 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000003324d830 11. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000033248983 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003b82b8f7 13. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:0: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000003bdff695 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000034d2837e 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d111cc 16. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cfd8b2 17. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034cf6172 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5bf1 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 27. ? @ 0x00007f100c857ac3 28. ? @ 0x00007f100c8e9850 2025.10.23 23:38:05.220416 [ 7565 ] {0882d2ae-e57b-4205-ace7-9abbd2fd9897} TCPHandler: Code: 36. DB::Exception: Cannot sleep infinite, very large or negative amount of time (not implemented). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. DB::FunctionSleep<(DB::FunctionSleepVariant)0>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0ba11d 5. DB::FunctionSleep<(DB::FunctionSleepVariant)0>::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b8d74 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000003324d830 11. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000033248983 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003b82b8f7 13. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:0: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000003bdff695 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000034d2837e 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d111cc 16. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cfd8b2 17. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034cf6172 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5bf1 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 27. ? @ 0x00007f100c857ac3 28. ? @ 0x00007f100c8e9850 2025.10.23 23:38:05.344079 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:05.643468 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:06.163527 [ 3903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:06.382198 [ 3903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:06.657315 [ 3903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:07.265779 [ 3903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:07.476927 [ 3903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:07.678285 [ 3903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:08.132689 [ 9763 ] {} ExternalDictionaries: Could not update cache dictionary '`01280_db`.ssd_dict (d07dd6e8-7833-415b-822f-58a59d9b6557)', next update is scheduled at 2025-10-23 23:38:10: 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202dea34 6. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039a5dbc5 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003bf2b229 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bf26bba 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003bf26345 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bf3d5b9 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2045: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf42fe0 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be48783 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003beb6da5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034cf5e6d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034cf5881 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:173: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x0000000020b1bdd1 19. ./contrib/llvm-project/libcxx/include/string:1499: DB::ClickHouseDictionarySource::loadKeys(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector> const&) @ 0x0000000020b1cb6e 20. DB::CacheDictionary<(DB::DictionaryKeyType)1>::update(std::shared_ptr>) @ 0x0000000021401350 21. 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>&&) @ 0x0000000021417ab1 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)1>::updateThreadFunction() @ 0x000000002142024a 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002142cdff 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:08.187163 [ 2904 ] {} DNSResolver: Cannot resolve host (non.existing.host.name), error 0: Host not found. 2025.10.23 23:38:08.188592 [ 2904 ] {} AddressPatterns: Failed to check if the allowed client hosts contain address 2001:3984:3989::242:ac11:2. DB::NetException: Not found address of host: non.existing.host.name, code = 198 2025.10.23 23:38:08.339625 [ 3903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:08.530930 [ 3903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:08.700647 [ 3903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:09.440850 [ 3903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:09.472167 [ 7565 ] {07f46294-76f0-4cb5-bf83-9353f34e1ada} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, jobs=0): (while reading column id): (while reading from part /var/lib/clickhouse/store/b8d/b8db3d6a-6199-4d9d-9ab7-f9a99f2d7089/-2_0_0_0/ in table test_3.table1 (b8db3d6a-6199-4d9d-9ab7-f9a99f2d7089) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:45904) (comment: 01870_modulo_partition_key.sql) (in query: select id from table1 where id % 200 = 2 OR id % 200 = -2 order by id;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000003075641a 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030755c60 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000307521d1 9. ./src/IO/AsynchronousReader.h:48: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000003073084e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000003073196f 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./src/IO/ReadBuffer.h:106: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x00000000320e80f8 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x00000000320ec44e 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x00000000320ed00d 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x00000000327a4627 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000032642210 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:216: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039c8e35d 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:0: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ce6eb1 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039cb3032 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039cd6816 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000039ccef53 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000039d4a566 23. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000003bfe52b4 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:206: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d3c6b0 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf89b85 26. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 27. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 31. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 2025.10.23 23:38:09.476843 [ 7565 ] {07f46294-76f0-4cb5-bf83-9353f34e1ada} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, jobs=0): (while reading column id): (while reading from part /var/lib/clickhouse/store/b8d/b8db3d6a-6199-4d9d-9ab7-f9a99f2d7089/-2_0_0_0/ in table test_3.table1 (b8db3d6a-6199-4d9d-9ab7-f9a99f2d7089) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000003075641a 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030755c60 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000307521d1 9. ./src/IO/AsynchronousReader.h:48: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000003073084e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000003073196f 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./src/IO/ReadBuffer.h:106: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x00000000320e80f8 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x00000000320ec44e 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x00000000320ed00d 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x00000000327a4627 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000032642210 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:216: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039c8e35d 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:0: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ce6eb1 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039cb3032 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039cd6816 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000039ccef53 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000039d4a566 23. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000003bfe52b4 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:206: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d3c6b0 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf89b85 26. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 27. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 31. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 2025.10.23 23:38:09.596971 [ 3903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:09.739064 [ 3903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:10.213941 [ 9557 ] {31718ad4-db55-4ddb-81e6-48556b684707} executeQuery: Code: 510. DB::Exception: Update failed for dictionary '`01280_db`.ssd_dict (d07dd6e8-7833-415b-822f-58a59d9b6557)': Code: 510. DB::Exception: Update failed for dictionary `01280_db`.ssd_dict (d07dd6e8-7833-415b-822f-58a59d9b6557) : 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202dea34 6. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039a5dbc5 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003bf2b229 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bf26bba 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003bf26345 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bf3d5b9 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2045: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf42fe0 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be48783 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003beb6da5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034cf5e6d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034cf5881 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:173: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x0000000020b1bdd1 19. ./contrib/llvm-project/libcxx/include/string:1499: DB::ClickHouseDictionarySource::loadKeys(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector> const&) @ 0x0000000020b1cb6e 20. DB::CacheDictionary<(DB::DictionaryKeyType)1>::update(std::shared_ptr>) @ 0x0000000021401350 21. 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>&&) @ 0x0000000021417ab1 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)1>::updateThreadFunction() @ 0x000000002142024a 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002142cdff 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10542.altinitytest (altinity build)): In scope SELECT dictGetUInt64('01280_db.ssd_dict', 'a', ('1', toInt32(3))). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:45888) (comment: 01280_ssd_complex_key_dictionary.sh) (in query: SELECT dictGetUInt64('01280_db.ssd_dict', 'a', tuple('1', toInt32(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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa0996d 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)1>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002141fed7 5. DB::CacheDictionary<(DB::DictionaryKeyType)1>::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 @ 0x00000000213f4efd 6. DB::CacheDictionary<(DB::DictionaryKeyType)1>::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 @ 0x00000000213f252e 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 @ 0x00000000096b12cd 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000096a8479 9. DB::FunctionDictGetImpl, DB::NameDictGetUInt64, (DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000096f783f 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 11. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 18. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 21. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 2025.10.23 23:38:10.216221 [ 9557 ] {31718ad4-db55-4ddb-81e6-48556b684707} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary '`01280_db`.ssd_dict (d07dd6e8-7833-415b-822f-58a59d9b6557)': Code: 510. DB::Exception: Update failed for dictionary `01280_db`.ssd_dict (d07dd6e8-7833-415b-822f-58a59d9b6557) : 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202dea34 6. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039a5dbc5 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003bf2b229 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bf26bba 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003bf26345 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bf3d5b9 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2045: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf42fe0 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be48783 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003beb6da5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034cf5e6d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034cf5881 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:173: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x0000000020b1bdd1 19. ./contrib/llvm-project/libcxx/include/string:1499: DB::ClickHouseDictionarySource::loadKeys(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector> const&) @ 0x0000000020b1cb6e 20. DB::CacheDictionary<(DB::DictionaryKeyType)1>::update(std::shared_ptr>) @ 0x0000000021401350 21. 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>&&) @ 0x0000000021417ab1 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)1>::updateThreadFunction() @ 0x000000002142024a 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002142cdff 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10542.altinitytest (altinity build)): In scope SELECT dictGetUInt64('01280_db.ssd_dict', 'a', ('1', toInt32(3))). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa0996d 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)1>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002141fed7 5. DB::CacheDictionary<(DB::DictionaryKeyType)1>::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 @ 0x00000000213f4efd 6. DB::CacheDictionary<(DB::DictionaryKeyType)1>::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 @ 0x00000000213f252e 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 @ 0x00000000096b12cd 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000096a8479 9. DB::FunctionDictGetImpl, DB::NameDictGetUInt64, (DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000096f783f 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 11. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 18. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 21. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 2025.10.23 23:38:10.513668 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:10.690176 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:10.760776 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:11.585544 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:11.836505 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:11.846856 [ 4649 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:12.641923 [ 4649 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:12.904511 [ 3895 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:12.913961 [ 4745 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:13.582103 [ 2903 ] {274c34a4-de92-40e9-848b-c3423ea39841} executeQuery: Code: 53. DB::Exception: Dictionary `01280_db`.ssd_dict (d07dd6e8-7833-415b-822f-58a59d9b6557) key lookup structure does not match, expected (String, Int32): In scope SELECT dictGetUInt64('01280_db.ssd_dict', 'a', tuple(toInt32(3))). (TYPE_MISMATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:46082) (comment: 01280_ssd_complex_key_dictionary.sh) (in query: SELECT dictGetUInt64('01280_db.ssd_dict', 'a', tuple(toInt32(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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./src/Dictionaries/IDictionary.h:151: DB::IDictionary::convertKeyColumns(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, std::vector, std::allocator>>&) const @ 0x0000000020d55219 5. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000096a70e2 6. DB::FunctionDictGetImpl, DB::NameDictGetUInt64, (DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000096f783f 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 2025.10.23 23:38:13.584267 [ 2903 ] {274c34a4-de92-40e9-848b-c3423ea39841} TCPHandler: Code: 53. DB::Exception: Dictionary `01280_db`.ssd_dict (d07dd6e8-7833-415b-822f-58a59d9b6557) key lookup structure does not match, expected (String, Int32): In scope SELECT dictGetUInt64('01280_db.ssd_dict', 'a', tuple(toInt32(3))). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./src/Dictionaries/IDictionary.h:151: DB::IDictionary::convertKeyColumns(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, std::vector, std::allocator>>&) const @ 0x0000000020d55219 5. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000096a70e2 6. DB::FunctionDictGetImpl, DB::NameDictGetUInt64, (DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000096f783f 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 2025.10.23 23:38:13.714103 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:13.933663 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:13.971461 [ 4745 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:14.334518 [ 2903 ] {ee568710-c703-4a49-9902-bf4443b55902} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:46214) (comment: 01280_ssd_complex_key_dictionary.sh) (in query: DROP DICTIONARY 01280_db.ssd_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349417ab 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:38:14.337446 [ 2903 ] {ee568710-c703-4a49-9902-bf4443b55902} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349417ab 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:38:14.698726 [ 4649 ] {61795501-81aa-4db3-8786-1f7c3d2442cd} executeQuery: Code: 57. DB::Exception: Table test_tdioenku.rep_fsync_r1 already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:46152) (comment: 01643_replicated_merge_tree_fsync_smoke.sql) (in query: CREATE TABLE rep_fsync_r1 (`key` Int) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/rep_fsync', 'r1') ORDER BY key SETTINGS min_rows_for_wide_part = 2, fsync_after_insert = 1, index_granularity = 49075, min_bytes_for_wide_part = 304913164, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 90, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 283497021, compact_parts_max_granules_to_buffer = 92, compact_parts_merge_max_bytes_to_prefetch_part = 29196349, merge_max_block_size = 1026, old_parts_lifetime = 429., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 6581454027, index_granularity_bytes = 16625052, concurrent_part_removal_threshold = 94, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 59988, primary_key_compress_block_size = 59109), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:38:14.700738 [ 4649 ] {61795501-81aa-4db3-8786-1f7c3d2442cd} TCPHandler: Code: 57. DB::Exception: Table test_tdioenku.rep_fsync_r1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:38:14.761957 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:14.956732 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:15.032688 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:15.857148 [ 3895 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:15.988759 [ 3895 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:16.082588 [ 3895 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:16.702550 [ 4745 ] {4a7ed9bf-3dfc-4e3d-bdb1-270f7906c8b2} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:33958) (comment: 01280_ssd_complex_key_dictionary.sh) (in query: DROP DATABASE IF EXISTS 01280_db;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349417ab 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>>>&) @ 0x0000000034947b8d 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:16.705862 [ 4745 ] {4a7ed9bf-3dfc-4e3d-bdb1-270f7906c8b2} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349417ab 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>>>&) @ 0x0000000034947b8d 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:16.946126 [ 3895 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:17.054697 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:17.146589 [ 4745 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:17.732157 [ 3903 ] {67b9760f-e8ce-4980-a832-608b74a95f60} executeQuery: Code: 57. DB::Exception: Table test_3.table_00609 already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:46040) (comment: 00609_prewhere_and_default.sql) (in query: CREATE TABLE table_00609 (`key` UInt64, `val` UInt64) ENGINE = MergeTree ORDER BY key SETTINGS index_granularity = 8192, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 49, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 400014129, compact_parts_max_granules_to_buffer = 234, compact_parts_merge_max_bytes_to_prefetch_part = 1105356, merge_max_block_size = 6169, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 22767327, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 52259, primary_key_compress_block_size = 8932), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:38:17.734146 [ 3903 ] {67b9760f-e8ce-4980-a832-608b74a95f60} TCPHandler: Code: 57. DB::Exception: Table test_3.table_00609 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:38:18.026358 [ 4745 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:18.179247 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:18.182813 [ 4745 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:18.753073 [ 3895 ] {25c76a85-f09f-422e-b04d-411c20da6282} executeQuery: Code: 215. DB::Exception: Column s1.half is not under aggregate function and not in GROUP BY keys. In query SELECT count(s0.number), s1.half FROM system.numbers AS s0 INNER JOIN (SELECT number, number / 2 AS half FROM system.numbers LIMIT 10) AS s1 ON s0.number = s1.number GROUP BY s0.number > 5 LIMIT 10. (NOT_AN_AGGREGATE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:34022) (comment: 03111_inner_join_group_by.sql) (in query: SELECT count(s0.number), s1.half FROM system.numbers AS s0 INNER JOIN ( SELECT number, number / 2 AS half FROM system.numbers LIMIT 10 ) AS s1 ON s0.number = s1.number GROUP BY s0.number > 5 LIMIT 10 -- {serverError NOT_AN_AGGREGATE} ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:140: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000033596407 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000335956a2 6. ./build_docker/./src/Analyzer/ValidationUtils.cpp:0: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000033593a48 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003343ad52 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:38:18.755807 [ 3895 ] {25c76a85-f09f-422e-b04d-411c20da6282} TCPHandler: Code: 215. DB::Exception: Column s1.half is not under aggregate function and not in GROUP BY keys. In query SELECT count(s0.number), s1.half FROM system.numbers AS s0 INNER JOIN (SELECT number, number / 2 AS half FROM system.numbers LIMIT 10) AS s1 ON s0.number = s1.number GROUP BY s0.number > 5 LIMIT 10. (NOT_AN_AGGREGATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:140: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000033596407 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000335956a2 6. ./build_docker/./src/Analyzer/ValidationUtils.cpp:0: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000033593a48 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003343ad52 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:38:19.084864 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:19.265898 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:19.267880 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:20.212350 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:20.345926 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:20.552872 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:21.295427 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:21.418166 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:21.418314 [ 3895 ] {60b5e66f-f9dd-4100-a74f-ee3e2df9779c} DynamicQueryHandler: Code: 271. DB::Exception: Can't decompress data: header is corrupt with compressed block size 0. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Compression/ICompressionCodec.cpp:117: DB::ICompressionCodec::readCompressedBlockSize(char const*) const @ 0x00000000322213c6 5. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:143: DB::readHeaderAndGetCodecAndSize(char const*, char8_t, std::shared_ptr&, unsigned long&, unsigned long&, bool, bool) @ 0x00000000320e627b 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x00000000320e5323 7. ./build_docker/./src/Compression/CompressedReadBuffer.cpp:12: non-virtual thunk to DB::CompressedReadBuffer::nextImpl() @ 0x00000000320e460d 8. DB::ReadBuffer::next() @ 0x00000000095b468f 9. ./build_docker/./src/IO/ReadBuffer.cpp:0: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x0000000030f421c6 10. DB::ReadBuffer::next() @ 0x00000000095b468f 11. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:88: DB::ConcatReadBuffer::nextImpl() @ 0x000000003367fad7 12. DB::ReadBuffer::next() @ 0x00000000095b468f 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c4c82 14. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 15. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 16. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 22. ? @ 0x00007f100c857ac3 23. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:21.582222 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:22.397331 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:22.586813 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:22.609453 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:23.450643 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:23.630257 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:23.633074 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:24.462552 [ 3177 ] {} DNSResolver: Cannot resolve host (non.existing.host.name), error 0: Host not found. 2025.10.23 23:38:24.546103 [ 9453 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:24.699826 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:24.908077 [ 9453 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:25.516878 [ 9453 ] {146bdd2a-ed60-4993-9649-c14837b48a66} PostgreSQLConnectionPool: Connection error: connection to server at "127.121.0.1", port 5432 failed: Connection refused Is the server running on that host and accepting TCP/IP connections? 2025.10.23 23:38:25.517408 [ 9453 ] {146bdd2a-ed60-4993-9649-c14837b48a66} PostgreSQLConnectionPool: Connection error: connection to server at "127.121.0.1", port 5432 failed: Connection refused Is the server running on that host and accepting TCP/IP connections? 2025.10.23 23:38:25.597908 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:25.827067 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:25.955109 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:26.260695 [ 9453 ] {146bdd2a-ed60-4993-9649-c14837b48a66} executeQuery: Code: 614. DB::Exception: Try 2. Connection to `127.121.0.1:5432` failed with error: connection to server at "127.121.0.1", port 5432 failed: Connection refused Is the server running on that host and accepting TCP/IP connections? . (POSTGRESQL_CONNECTION_FAILURE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:50824) (comment: 02888_system_tables_with_inaccessible_table_function.sql) (in query: CREATE TABLE test_2h2oy0x1.tablefunc01_without_schema AS postgresql('127.121.0.1:5432', 'postgres_db', 'postgres_table', 'postgres_user', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: DB::Exception::Exception(PreformattedMessage const&, int) @ 0x000000002fde43dd 3. ./build_docker/./src/Core/PostgreSQL/PoolWithFailover.cpp:148: postgres::PoolWithFailover::get() @ 0x0000000030c21ec4 4. ./build_docker/./src/Storages/StoragePostgreSQL.cpp:102: DB::StoragePostgreSQL::getTableStructureFromData(std::shared_ptr const&, String const&, String const&, std::shared_ptr const&) @ 0x00000000386a0df3 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::(anonymous namespace)::TableFunctionPostgreSQL::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002feac23a 6. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348b1411 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cde07 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:26.262221 [ 9453 ] {146bdd2a-ed60-4993-9649-c14837b48a66} TCPHandler: Code: 614. DB::Exception: Try 2. Connection to `127.121.0.1:5432` failed with error: connection to server at "127.121.0.1", port 5432 failed: Connection refused Is the server running on that host and accepting TCP/IP connections? . (POSTGRESQL_CONNECTION_FAILURE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: DB::Exception::Exception(PreformattedMessage const&, int) @ 0x000000002fde43dd 3. ./build_docker/./src/Core/PostgreSQL/PoolWithFailover.cpp:148: postgres::PoolWithFailover::get() @ 0x0000000030c21ec4 4. ./build_docker/./src/Storages/StoragePostgreSQL.cpp:102: DB::StoragePostgreSQL::getTableStructureFromData(std::shared_ptr const&, String const&, String const&, std::shared_ptr const&) @ 0x00000000386a0df3 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::(anonymous namespace)::TableFunctionPostgreSQL::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002feac23a 6. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348b1411 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cde07 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:26.277997 [ 9453 ] {b8d62b1d-96c6-4949-9181-8b8b833438ab} mysqlxx::Pool: Failed to connect to MySQL (mysql_db@127.123.0.1:3306 as user mysql_user): mysqlxx::ConnectionFailed 2025.10.23 23:38:26.278340 [ 9453 ] {b8d62b1d-96c6-4949-9181-8b8b833438ab} Application: Connection to mysql_db@127.123.0.1:3306 as user mysql_user failed: mysqlxx::ConnectionFailed: Can't connect to MySQL server on '127.123.0.1' (115) ((nullptr):0) 2025.10.23 23:38:26.278524 [ 9453 ] {b8d62b1d-96c6-4949-9181-8b8b833438ab} Application: Connection to mysql failed 1 times 2025.10.23 23:38:26.278986 [ 9453 ] {b8d62b1d-96c6-4949-9181-8b8b833438ab} mysqlxx::Pool: Failed to connect to MySQL (mysql_db@127.123.0.1:3306 as user mysql_user): mysqlxx::ConnectionFailed 2025.10.23 23:38:26.279138 [ 9453 ] {b8d62b1d-96c6-4949-9181-8b8b833438ab} Application: Connection to mysql_db@127.123.0.1:3306 as user mysql_user failed: mysqlxx::ConnectionFailed: Can't connect to MySQL server on '127.123.0.1' (115) ((nullptr):0) 2025.10.23 23:38:26.279196 [ 9453 ] {b8d62b1d-96c6-4949-9181-8b8b833438ab} Application: Connection to mysql failed 2 times 2025.10.23 23:38:26.279551 [ 9453 ] {b8d62b1d-96c6-4949-9181-8b8b833438ab} mysqlxx::Pool: Failed to connect to MySQL (mysql_db@127.123.0.1:3306 as user mysql_user): mysqlxx::ConnectionFailed 2025.10.23 23:38:26.279685 [ 9453 ] {b8d62b1d-96c6-4949-9181-8b8b833438ab} Application: Connection to mysql_db@127.123.0.1:3306 as user mysql_user failed: mysqlxx::ConnectionFailed: Can't connect to MySQL server on '127.123.0.1' (115) ((nullptr):0) 2025.10.23 23:38:26.279843 [ 9453 ] {b8d62b1d-96c6-4949-9181-8b8b833438ab} Application: Connection to mysql failed 3 times 2025.10.23 23:38:26.664759 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:26.926811 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:27.056456 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:27.403415 [ 9453 ] {b8d62b1d-96c6-4949-9181-8b8b833438ab} executeQuery: Code: 279. DB::Exception: Connections to mysql failed: mysql_db@127.123.0.1:3306 as user mysql_user, ERROR 2002 : mysqlxx::ConnectionFailed: Can't connect to MySQL server on '127.123.0.1' (115) ((nullptr):0). (ALL_CONNECTION_TRIES_FAILED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:50824) (comment: 02888_system_tables_with_inaccessible_table_function.sql) (in query: CREATE TABLE test_2h2oy0x1.tablefunc02_without_schema AS mysql('127.123.0.1:3306', 'mysql_db', 'mysql_table', 'mysql_user', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000842350a 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:0: mysqlxx::PoolWithFailover::get() @ 0x000000004037dc29 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:0: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x0000000032dca6f4 6. ./contrib/llvm-project/libcxx/include/vector:438: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x0000000038688f15 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::(anonymous namespace)::TableFunctionMySQL::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002fea779a 8. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348b1411 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cde07 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:38:27.404845 [ 9453 ] {b8d62b1d-96c6-4949-9181-8b8b833438ab} TCPHandler: Code: 279. DB::Exception: Connections to mysql failed: mysql_db@127.123.0.1:3306 as user mysql_user, ERROR 2002 : mysqlxx::ConnectionFailed: Can't connect to MySQL server on '127.123.0.1' (115) ((nullptr):0). (ALL_CONNECTION_TRIES_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000842350a 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:0: mysqlxx::PoolWithFailover::get() @ 0x000000004037dc29 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:0: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x0000000032dca6f4 6. ./contrib/llvm-project/libcxx/include/vector:438: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x0000000038688f15 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::(anonymous namespace)::TableFunctionMySQL::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002fea779a 8. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348b1411 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cde07 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:38:27.714996 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:27.970684 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:28.119649 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:28.586791 [ 9453 ] {cefb0848-863a-445f-b4a5-85bf1fac2eba} PostgreSQLConnectionPool: Connection error: connection to server at "127.121.0.1", port 5432 failed: Connection refused Is the server running on that host and accepting TCP/IP connections? 2025.10.23 23:38:28.621859 [ 9453 ] {cefb0848-863a-445f-b4a5-85bf1fac2eba} PostgreSQLConnectionPool: Connection error: connection to server at "127.121.0.1", port 5432 failed: Connection refused Is the server running on that host and accepting TCP/IP connections? 2025.10.23 23:38:28.827164 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:29.018727 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:29.040295 [ 6965 ] {c85b5847-0201-455e-ba63-d163a52dc33f} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage SystemNumbers. (NOT_IMPLEMENTED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:50954) (comment: 00979_quantileExcatExclusive_and_Inclusive.sql) (in query: DROP TABLE num;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000002ffc5e67 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003493f2d5 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:38:29.042123 [ 6965 ] {c85b5847-0201-455e-ba63-d163a52dc33f} TCPHandler: Code: 48. DB::Exception: Truncate is not supported by storage SystemNumbers. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000002ffc5e67 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003493f2d5 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:38:29.271413 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:29.873713 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:30.084776 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:30.313525 [ 9453 ] {cefb0848-863a-445f-b4a5-85bf1fac2eba} executeQuery: Code: 614. DB::Exception: Try 2. Connection to `127.121.0.1:5432` failed with error: connection to server at "127.121.0.1", port 5432 failed: Connection refused Is the server running on that host and accepting TCP/IP connections? . (POSTGRESQL_CONNECTION_FAILURE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:50824) (comment: 02888_system_tables_with_inaccessible_table_function.sql) (in query: SELECT count() FROM test_2h2oy0x1.tablefunc01), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: DB::Exception::Exception(PreformattedMessage const&, int) @ 0x000000002fde43dd 3. ./build_docker/./src/Core/PostgreSQL/PoolWithFailover.cpp:148: postgres::PoolWithFailover::get() @ 0x0000000030c21ec4 4. ./build_docker/./src/Storages/StoragePostgreSQL.cpp:201: DB::StoragePostgreSQL::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000386a20b5 5. ./src/Storages/StorageTableFunction.h:0: DB::StorageTableFunctionProxy::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000306fd9a0 6. ./src/Processors/QueryPlan/QueryPlan.h:53: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000034d80c82 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1777: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d67094 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0b8de 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cfd8b2 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034cf6172 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5bf1 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:38:30.315515 [ 9453 ] {cefb0848-863a-445f-b4a5-85bf1fac2eba} TCPHandler: Code: 614. DB::Exception: Try 2. Connection to `127.121.0.1:5432` failed with error: connection to server at "127.121.0.1", port 5432 failed: Connection refused Is the server running on that host and accepting TCP/IP connections? . (POSTGRESQL_CONNECTION_FAILURE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: DB::Exception::Exception(PreformattedMessage const&, int) @ 0x000000002fde43dd 3. ./build_docker/./src/Core/PostgreSQL/PoolWithFailover.cpp:148: postgres::PoolWithFailover::get() @ 0x0000000030c21ec4 4. ./build_docker/./src/Storages/StoragePostgreSQL.cpp:201: DB::StoragePostgreSQL::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000386a20b5 5. ./src/Storages/StorageTableFunction.h:0: DB::StorageTableFunctionProxy::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000306fd9a0 6. ./src/Processors/QueryPlan/QueryPlan.h:53: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000034d80c82 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1777: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d67094 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0b8de 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cfd8b2 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034cf6172 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5bf1 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:38:30.345079 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:31.028127 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:31.158153 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:31.392746 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:32.009405 [ 9453 ] {ffbb2c35-299f-497b-afcc-0494ae9e2659} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage PostgreSQL. (NOT_IMPLEMENTED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:50824) (comment: 02888_system_tables_with_inaccessible_table_function.sql) (in query: DROP DATABASE IF EXISTS test_2h2oy0x1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000002ffc5e67 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&) @ 0x00000000306ffe26 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003493f2d5 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>>>&) @ 0x0000000034947b8d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:38:32.010978 [ 9453 ] {ffbb2c35-299f-497b-afcc-0494ae9e2659} TCPHandler: Code: 48. DB::Exception: Truncate is not supported by storage PostgreSQL. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000002ffc5e67 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&) @ 0x00000000306ffe26 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003493f2d5 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>>>&) @ 0x0000000034947b8d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:38:32.097102 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:32.192736 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:32.447023 [ 4694 ] {98ef8998-8b56-460c-813a-84a3126adbc7} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=778, jobs=755). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:51010) (comment: 02015_division_by_nullable.sql) (in query: SELECT intDiv(1, CAST(1, 'Nullable(UInt32)'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:38:32.451133 [ 4694 ] {98ef8998-8b56-460c-813a-84a3126adbc7} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=778, jobs=755). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:38:32.472792 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:32.944556 [ 3157 ] {} test_3.table1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.10.23 23:38:32.944761 [ 3364 ] {} test_3.`02691_drop_column_replicated` (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.10.23 23:38:32.944872 [ 3420 ] {} test_3.rmt (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.10.23 23:38:32.945014 [ 3189 ] {} test_15.r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.10.23 23:38:32.945650 [ 3443 ] {} test_3.`02691_drop_column_replicated` (1045b1a8-f37f-4f75-892a-b44e770b298b): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_3/test/02691_drop_column/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:32.945833 [ 3429 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000003cc8de51 3. ./src/Common/ZooKeeper/IKeeper.h:509: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003cd16a3e 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003cd2369f 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe6e6d 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe5f26 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe84e7 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe81ea 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000003a10064e 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000003889f11d 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f9f 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:32.945829 [ 3121 ] {} test_3.rmt (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /test/02253/02253_empty_part_checksums_test_3/rmt/async_blocks. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x0000000030538e6c 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe8649 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000003cbe7761 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x000000003a061e9e 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x000000003a04fe19 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:165: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a04156e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:50: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a03dd98 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003a06697f 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:32.945853 [ 3405 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000003cc8de51 3. ./src/Common/ZooKeeper/IKeeper.h:509: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003cd16a3e 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1383: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x000000003cd1a472 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x000000003cbf5306 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:610: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x000000003cbf42db 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000003cbf676b 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003cbf5ab3 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x000000003a0eb80c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889e7df 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:32.946188 [ 9678 ] {33a9010b-ecca-4e98-a957-290f5bab4c98} executeQuery: Code: 999. Coordination::Exception: Coordination error: Connection loss, path /test/db/test_11/max_log_ptr. (KEEPER_EXCEPTION) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:34192) (comment: 00557_alter_null_storage_tables.sql) (in query: CREATE TABLE null_00557 (x UInt8) ENGINE = Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x0000000030538e6c 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000003cbf6898 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003cbf5ab3 6. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ad5036 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a52a3c 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfab2 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:38:32.946340 [ 3295 ] {} test_3.`02691_drop_column_replicated` (1045b1a8-f37f-4f75-892a-b44e770b298b): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000003cc8de51 3. ./src/Common/ZooKeeper/IKeeper.h:509: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003cd16a3e 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003cd2369f 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe6e6d 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe5f26 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe84e7 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe81ea 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000003a10064e 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000003889f11d 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f9f 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:32.947553 [ 3121 ] {} test_3.rmt (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000003cc8de51 3. ./src/Common/ZooKeeper/IKeeper.h:509: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003cd16a3e 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000003cd20792 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryExistsNoThrow(String const&, std::function) @ 0x000000003cbf3581 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003cbf26a1 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000003cbf3a70 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003cbea871 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000003a0439c9 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a04133c 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:50: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a03dd98 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003a06697f 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 15. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:32.949083 [ 9678 ] {33a9010b-ecca-4e98-a957-290f5bab4c98} TCPHandler: Code: 999. Coordination::Exception: Coordination error: Connection loss, path /test/db/test_11/max_log_ptr. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x0000000030538e6c 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000003cbf6898 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003cbf5ab3 6. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ad5036 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a52a3c 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfab2 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:38:33.156669 [ 6965 ] {89bb1088-7c55-4b87-ae60-82d6c2790b63} void DB::FileCacheFactory::updateSettingsFromConfig(const Poco::Util::AbstractConfiguration &): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=778, jobs=755). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::CacheMetadata::setBackgroundDownloadThreads(unsigned long) @ 0x0000000035b84d6f 7. ./build_docker/./src/Interpreters/Cache/FileCache.cpp:1526: DB::FileCache::applySettingsIfPossible(DB::FileCacheSettings const&, DB::FileCacheSettings&) @ 0x0000000035acf28e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::FileCacheFactory::updateSettingsFromConfig(Poco::Util::AbstractConfiguration const&) @ 0x0000000035b0315c 9. ./build_docker/./programs/server/Server.cpp:1757: DB::Server::main(std::vector> const&)::$_6::operator()(Poco::AutoPtr, bool) const @ 0x00000000206465da 10. ./base/poco/Foundation/include/Poco/AutoPtr.h:90: void std::__function::__policy_invoker, bool)>::__call_impl> const&)::$_6, void (Poco::AutoPtr, bool)>>(std::__function::__policy_storage const*, Poco::AutoPtr&&, bool) @ 0x000000002063f7ff 11. ./base/poco/Foundation/include/Poco/AutoPtr.h:90: DB::ConfigReloader::reloadIfNewer(bool, bool, bool, bool) @ 0x000000003cb4aca7 12. ./src/Common/Config/ConfigReloader.h:50: void std::__function::__policy_invoker::__call_impl> const&)::$_13, void ()>>(std::__function::__policy_storage const*) @ 0x000000002064e277 13. ./build_docker/./src/Interpreters/Context.cpp:4747: DB::Context::reloadConfig() const @ 0x00000000337a0fda 14. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:592: DB::InterpreterSystemQuery::execute() @ 0x0000000035967268 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:33.159356 [ 6965 ] {89bb1088-7c55-4b87-ae60-82d6c2790b63} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=778, jobs=755). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:51030) (comment: 02933_change_cache_setting_without_restart.sh) (in query: SYSTEM RELOAD CONFIG), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::CacheMetadata::setBackgroundDownloadThreads(unsigned long) @ 0x0000000035b84d6f 7. ./build_docker/./src/Interpreters/Cache/FileCache.cpp:1526: DB::FileCache::applySettingsIfPossible(DB::FileCacheSettings const&, DB::FileCacheSettings&) @ 0x0000000035acf28e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::FileCacheFactory::updateSettingsFromConfig(Poco::Util::AbstractConfiguration const&) @ 0x0000000035b0315c 9. ./build_docker/./programs/server/Server.cpp:1757: DB::Server::main(std::vector> const&)::$_6::operator()(Poco::AutoPtr, bool) const @ 0x00000000206465da 10. ./base/poco/Foundation/include/Poco/AutoPtr.h:90: void std::__function::__policy_invoker, bool)>::__call_impl> const&)::$_6, void (Poco::AutoPtr, bool)>>(std::__function::__policy_storage const*, Poco::AutoPtr&&, bool) @ 0x000000002063f7ff 11. ./base/poco/Foundation/include/Poco/AutoPtr.h:90: DB::ConfigReloader::reloadIfNewer(bool, bool, bool, bool) @ 0x000000003cb4aca7 12. ./src/Common/Config/ConfigReloader.h:50: void std::__function::__policy_invoker::__call_impl> const&)::$_13, void ()>>(std::__function::__policy_storage const*) @ 0x000000002064e277 13. ./build_docker/./src/Interpreters/Context.cpp:4747: DB::Context::reloadConfig() const @ 0x00000000337a0fda 14. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:592: DB::InterpreterSystemQuery::execute() @ 0x0000000035967268 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:38:33.161524 [ 6965 ] {89bb1088-7c55-4b87-ae60-82d6c2790b63} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=778, jobs=755). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::CacheMetadata::setBackgroundDownloadThreads(unsigned long) @ 0x0000000035b84d6f 7. ./build_docker/./src/Interpreters/Cache/FileCache.cpp:1526: DB::FileCache::applySettingsIfPossible(DB::FileCacheSettings const&, DB::FileCacheSettings&) @ 0x0000000035acf28e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::FileCacheFactory::updateSettingsFromConfig(Poco::Util::AbstractConfiguration const&) @ 0x0000000035b0315c 9. ./build_docker/./programs/server/Server.cpp:1757: DB::Server::main(std::vector> const&)::$_6::operator()(Poco::AutoPtr, bool) const @ 0x00000000206465da 10. ./base/poco/Foundation/include/Poco/AutoPtr.h:90: void std::__function::__policy_invoker, bool)>::__call_impl> const&)::$_6, void (Poco::AutoPtr, bool)>>(std::__function::__policy_storage const*, Poco::AutoPtr&&, bool) @ 0x000000002063f7ff 11. ./base/poco/Foundation/include/Poco/AutoPtr.h:90: DB::ConfigReloader::reloadIfNewer(bool, bool, bool, bool) @ 0x000000003cb4aca7 12. ./src/Common/Config/ConfigReloader.h:50: void std::__function::__policy_invoker::__call_impl> const&)::$_13, void ()>>(std::__function::__policy_storage const*) @ 0x000000002064e277 13. ./build_docker/./src/Interpreters/Context.cpp:4747: DB::Context::reloadConfig() const @ 0x00000000337a0fda 14. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:592: DB::InterpreterSystemQuery::execute() @ 0x0000000035967268 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:38:33.184764 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:33.218196 [ 4799 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:33.514010 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:33.908058 [ 3895 ] {252a9c2b-ab88-45b4-835c-5fe52978dd97} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage MySQL. (NOT_IMPLEMENTED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59382) (comment: 02888_system_tables_with_inaccessible_table_function.sql) (in query: DROP DATABASE IF EXISTS test_2h2oy0x1 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000002ffc5e67 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&) @ 0x00000000306ffe26 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003493f2d5 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>>>&) @ 0x0000000034947b8d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 12. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 13. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:38:33.911249 [ 3895 ] {252a9c2b-ab88-45b4-835c-5fe52978dd97} DynamicQueryHandler: Code: 48. DB::Exception: Truncate is not supported by storage MySQL. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000002ffc5e67 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&) @ 0x00000000306ffe26 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003493f2d5 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>>>&) @ 0x0000000034947b8d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 12. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 13. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:34.279507 [ 4799 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:34.312306 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:34.571444 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:35.351289 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:35.442486 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:35.606869 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:36.454309 [ 4799 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:36.505643 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:36.581901 [ 3653 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {c84fffe3-f7b9-426e-917b-60cee886efa2::202510_1_75_15}: 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 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) @ 0x0000000039c89948 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000003999bfb7 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 @ 0x00000000399942f0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000039d15c04 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&) @ 0x0000000039d20399 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) @ 0x0000000039d1c606 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000396308a4 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x00000000396235dd 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000003963b3e0 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x00000000396504a0 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3c455d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:36.667040 [ 3646 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {9a375c2d-1765-4ead-bc63-7dc0959ac450::202510_120_130_2}: 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 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) @ 0x0000000039c89948 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000003999bfb7 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 @ 0x00000000399942f0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000039d15c04 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&) @ 0x0000000039d20399 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) @ 0x0000000039d1c606 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000396308a4 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x00000000396235dd 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000003963b3e0 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x00000000396504a0 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3c455d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:36.680716 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:37.533528 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:37.557548 [ 3903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:37.714382 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:38.566369 [ 3903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:38.617633 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:38.765924 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:39.202433 [ 9557 ] {a7ef36d4-2b1f-47f0-bc27-f28df226bbfd} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=778, jobs=748). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:51112) (comment: 01533_multiple_nested.sql) (in query: SELECT ProfileEvents['FileOpen'] - ProfileEvents['CreatedReadBufferDirectIOFailed'] FROM system.query_log WHERE (type = 'QueryFinish') AND (lower(query) LIKE lower('SELECT col1.a FROM %nested%')) 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:38:39.205868 [ 9557 ] {a7ef36d4-2b1f-47f0-bc27-f28df226bbfd} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=778, jobs=748). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:38:39.659911 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:39.691090 [ 3903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:39.841357 [ 3903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:39.920972 [ 9336 ] {ddc8f7e1-3b95-4760-b57e-70baaf32090a} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_3.t_async_inserts_flush FORMAT JSONEachRow' with query id 403dffcd-ad05-434a-a185-b7f15b26e143. DB::Exception: Cannot parse input: expected '"' before: 'str"};': (while reading the value of key a): (at row 1) 2025.10.23 23:38:40.729170 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:40.767219 [ 3903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:40.945787 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:41.706300 [ 2903 ] {34f996d1-a746-4967-8ef2-378916f878a6} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Buffer. (NOT_IMPLEMENTED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:54192) (comment: 00158_buffer_and_nonexistent_table.sql) (in query: DROP TABLE IF EXISTS test_3.mt_buffer_00158), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000002ffc5e67 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003493f2d5 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:38:41.707313 [ 2903 ] {34f996d1-a746-4967-8ef2-378916f878a6} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000002ffc5e67 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003493f2d5 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:38:41.821318 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:41.910529 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:41.997235 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:42.971660 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:43.022672 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:43.166593 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:43.293512 [ 3047 ] {} void DB::StorageBuffer::backgroundFlush(): 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/StorageBuffer.cpp:0: DB::StorageBuffer::flushAllBuffers(bool) @ 0x0000000038ddb12c 8. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x0000000038de8318 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038dec4ff 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:44.071066 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:44.077823 [ 4745 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:44.276891 [ 7759 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:44.915401 [ 7759 ] {338d1526-5449-42da-8d70-0865269e58d0} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:54394) (comment: 02313_filesystem_cache_seeks.sh) (in query: INSERT INTO test_02313 SELECT * FROM generateRandom('id Int32, val String') LIMIT 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 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*) @ 0x000000003aea17d9 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:38:44.922057 [ 7759 ] {338d1526-5449-42da-8d70-0865269e58d0} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 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*) @ 0x000000003aea17d9 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:38:45.009213 [ 3046 ] {} void DB::StorageBuffer::backgroundFlush(): 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/StorageBuffer.cpp:0: DB::StorageBuffer::flushAllBuffers(bool) @ 0x0000000038ddb12c 8. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x0000000038de8318 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038dec4ff 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:45.125661 [ 7759 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:45.126886 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:45.322499 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:45.340751 [ 4841 ] {ef195c21-67fa-4d8a-a3b8-473cbd428405} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:54304) (comment: 02317_distinct_in_order_optimization_explain.sh) (in query: explain pipeline select distinct * from distinct_in_order_explain), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202dea34 6. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039a5dbc5 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003bf2b229 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bf26bba 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003bf26345 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bf3d5b9 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2045: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf42fe0 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be48783 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003beb6da5 14. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:513: DB::InterpreterExplainQuery::executeImpl() @ 0x000000003495cb4c 15. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:0: DB::InterpreterExplainQuery::execute() @ 0x00000000349520a4 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:38:45.342830 [ 4841 ] {ef195c21-67fa-4d8a-a3b8-473cbd428405} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202dea34 6. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039a5dbc5 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003bf2b229 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bf26bba 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003bf26345 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bf3d5b9 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2045: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf42fe0 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be48783 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003beb6da5 14. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:513: DB::InterpreterExplainQuery::executeImpl() @ 0x000000003495cb4c 15. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:0: DB::InterpreterExplainQuery::execute() @ 0x00000000349520a4 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:38:45.836678 [ 4745 ] {fc05d63c-595a-4e96-94c2-c3fa1cc20f33} executeQuery: Code: 36. DB::Exception: Compression codec GCD does not compress anything. You may want to add generic compression algorithm after other transformations, like: GCD, LZ4. (Note: you can enable setting 'allow_suspicious_codecs' to skip this check). (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:54356) (comment: 02872_gcd_codec.sql) (in query: -- GCD codec can't be used stand-alone CREATE TEMPORARY TABLE table_gcd_codec (n UInt64 CODEC(GCD)) 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000001beae9ed 4. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:0: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000349314e3 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:700: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000348a9f99 6. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348af396 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cde07 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:45.838115 [ 4745 ] {fc05d63c-595a-4e96-94c2-c3fa1cc20f33} TCPHandler: Code: 36. DB::Exception: Compression codec GCD does not compress anything. You may want to add generic compression algorithm after other transformations, like: GCD, LZ4. (Note: you can enable setting 'allow_suspicious_codecs' to skip this check). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000001beae9ed 4. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:0: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000349314e3 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:700: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000348a9f99 6. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348af396 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cde07 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:46.159261 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:46.185147 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:46.452781 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:46.654663 [ 4745 ] {a6fd27b5-7998-4397-93a6-ee173ae6e45e} executeQuery: Code: 36. DB::Exception: Codec GCD cannot be applied to column String because it can only be used with Int*, UInt*, Decimal*, Date* or DateTime* types. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:54356) (comment: 02872_gcd_codec.sql) (in query: -- GCD codec rejects non-integer/decimal/datetime types CREATE TEMPORARY TABLE table_gcd_codec (str String CODEC(GCD, LZ4)) 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Compression/CompressionCodecGCD.cpp:253: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&, DB::IDataType const*)>::__call_impl (std::shared_ptr const&, DB::IDataType const*)>>(std::__function::__policy_storage const*, std::shared_ptr const&, DB::IDataType const*) @ 0x000000003221c928 5. ./build_docker/./src/Compression/CompressionFactory.cpp:131: DB::CompressionCodecFactory::getImpl(String const&, std::shared_ptr const&, DB::IDataType const*) const @ 0x0000000032108728 6. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:0: 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&) @ 0x0000000034932bf2 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:63: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x00000000326402a2 8. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000032640cad 9. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:0: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003492e424 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:700: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000348a9f99 11. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348af396 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cde07 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 2025.10.23 23:38:46.705205 [ 4745 ] {a6fd27b5-7998-4397-93a6-ee173ae6e45e} TCPHandler: Code: 36. DB::Exception: Codec GCD cannot be applied to column String because it can only be used with Int*, UInt*, Decimal*, Date* or DateTime* types. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Compression/CompressionCodecGCD.cpp:253: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&, DB::IDataType const*)>::__call_impl (std::shared_ptr const&, DB::IDataType const*)>>(std::__function::__policy_storage const*, std::shared_ptr const&, DB::IDataType const*) @ 0x000000003221c928 5. ./build_docker/./src/Compression/CompressionFactory.cpp:131: DB::CompressionCodecFactory::getImpl(String const&, std::shared_ptr const&, DB::IDataType const*) const @ 0x0000000032108728 6. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:0: 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&) @ 0x0000000034932bf2 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:63: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x00000000326402a2 8. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000032640cad 9. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:0: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003492e424 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:700: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000348a9f99 11. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348af396 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cde07 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 2025.10.23 23:38:47.251280 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:47.300054 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:47.507455 [ 7759 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:48.326117 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:48.351058 [ 7759 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:48.563938 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:49.377502 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:49.411428 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:49.444349 [ 9453 ] {15d42b47-603f-4ec9-b66e-331b9f903bac} executeQuery: Code: 57. DB::Exception: Table test_3.test_02313 already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:41078) (comment: 02313_filesystem_cache_seeks.sh) (in query: CREATE TABLE test_02313 (id Int32, val String) ENGINE = MergeTree() ORDER BY tuple() SETTINGS storage_policy = 'local_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:38:49.446697 [ 9453 ] {15d42b47-603f-4ec9-b66e-331b9f903bac} TCPHandler: Code: 57. DB::Exception: Table test_3.test_02313 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:38:49.645639 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:49.833170 [ 4841 ] {6adffc15-f26e-4a86-ace9-58098917fcc7} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=13). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:41092) (comment: 02313_filesystem_cache_seeks.sh) (in query: INSERT INTO test_02313 SELECT * FROM generateRandom('id Int32, val String') LIMIT 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 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*) @ 0x000000003aea17d9 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:38:49.894269 [ 4841 ] {6adffc15-f26e-4a86-ace9-58098917fcc7} TCPHandler: 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 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*) @ 0x000000003aea17d9 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:38:50.016645 [ 3041 ] {} void DB::StorageBuffer::backgroundFlush(): 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/StorageBuffer.cpp:0: DB::StorageBuffer::flushAllBuffers(bool) @ 0x0000000038ddb12c 8. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x0000000038de8318 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038dec4ff 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:50.399676 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:50.473999 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:50.693584 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:51.412261 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:51.523630 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:51.768928 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:51.856695 [ 4649 ] {b14a16ee-d537-480a-bcf1-d172ba7e317a} 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.10542.altinitytest (altinity build)) (from [::1]:54170) (comment: 01060_shutdown_table_after_detach.sql) (in query: DETACH 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:979: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000032a50c33 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a51799 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:222: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003493e6e9 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:38:51.858840 [ 4649 ] {b14a16ee-d537-480a-bcf1-d172ba7e317a} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:979: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000032a50c33 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a51799 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:222: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003493e6e9 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:38:51.897336 [ 2903 ] {29d9c3cf-0430-416e-baad-e9cc3b235168} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:45354) (comment: 02872_gcd_codec.sql) (in query: DROP DATABASE IF EXISTS test_c92z460k ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:38:51.900905 [ 2903 ] {29d9c3cf-0430-416e-baad-e9cc3b235168} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:51.921699 [ 4841 ] {ed30eaa7-99ca-4f63-8d47-656937130e4b} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:45362) (comment: 02872_gcd_codec.sql) (in query: DROP DATABASE IF EXISTS test_c92z460k ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:38:51.924000 [ 4841 ] {ed30eaa7-99ca-4f63-8d47-656937130e4b} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:52.539177 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:52.586467 [ 4675 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:52.607488 [ 9453 ] {d45aa6e0-11f4-44c1-a4cd-52fb65067856} executeQuery: Code: 57. DB::Exception: Table test_11.test already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 00974_bitmapContains_with_primary_key.sql) (in query: /* ddl_entry=query-0000000056 */ CREATE TABLE test_11.test UUID '093fe019-81e0-4529-8cbe-02e1f8b14497' (`num` UInt64, `str` String) ENGINE = MergeTree ORDER BY num SETTINGS index_granularity = 9942, min_bytes_for_wide_part = 250793257, ratio_of_defaults_for_sparse_serialization = 0.07200460880994797, replace_long_file_name_to_hash = false, max_file_name_length = 64, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 218496081, compact_parts_max_granules_to_buffer = 25, compact_parts_merge_max_bytes_to_prefetch_part = 6422664, merge_max_block_size = 16601, old_parts_lifetime = 236., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 85, min_merge_bytes_to_use_direct_io = 2697502045, index_granularity_bytes = 16356480, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 67791, primary_key_compress_block_size = 8452), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003395fc9e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000033958fac 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ad726d 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a52a3c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfab2 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:38:52.614734 [ 9453 ] {d45aa6e0-11f4-44c1-a4cd-52fb65067856} executeQuery: Code: 57. DB::Exception: Table test_11.test already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:41278) (comment: 00974_bitmapContains_with_primary_key.sql) (in query: CREATE TABLE test (`num` UInt64, `str` String) ENGINE = MergeTree ORDER BY num SETTINGS index_granularity = 9942, min_bytes_for_wide_part = 250793257, ratio_of_defaults_for_sparse_serialization = 0.07200460880994797, replace_long_file_name_to_hash = false, max_file_name_length = 64, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 218496081, compact_parts_max_granules_to_buffer = 25, compact_parts_merge_max_bytes_to_prefetch_part = 6422664, merge_max_block_size = 16601, old_parts_lifetime = 236., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 85, min_merge_bytes_to_use_direct_io = 2697502045, index_granularity_bytes = 16356480, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 67791, primary_key_compress_block_size = 8452), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003395fc9e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000033958fac 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ad726d 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a52a3c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfab2 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:38:52.617631 [ 9453 ] {d45aa6e0-11f4-44c1-a4cd-52fb65067856} TCPHandler: Code: 57. DB::Exception: Table test_11.test already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003395fc9e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000033958fac 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ad726d 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a52a3c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfab2 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:38:52.871371 [ 4675 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:53.621585 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:53.690074 [ 4675 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:53.948211 [ 4675 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:53.968075 [ 9557 ] {4d6f2d00-d57a-41a7-b280-6a1bf5ee3a31} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=778, jobs=748). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:41376) (comment: 01409_topK_merge.sql) (in query: select length(topK(20)(number)) from remote('127.{1,1}', currentDatabase(), data_01409);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:38:53.971984 [ 9557 ] {4d6f2d00-d57a-41a7-b280-6a1bf5ee3a31} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=778, jobs=748). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:38:54.747521 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:54.753728 [ 3895 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:54.995149 [ 4675 ] {956d37a9-d3b0-4853-ba30-83fc916e1a1d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, jobs=14). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:50862) (comment: 02313_filesystem_cache_seeks.sh) (in query: INSERT INTO test_02313 SELECT * FROM generateRandom('id Int32, val String') LIMIT 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 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*) @ 0x000000003aea17d9 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:38:55.001168 [ 4675 ] {956d37a9-d3b0-4853-ba30-83fc916e1a1d} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 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*) @ 0x000000003aea17d9 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:38:55.004964 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:55.839219 [ 4799 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:55.892973 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:56.060458 [ 4675 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:56.890119 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:56.906464 [ 4694 ] {450a7293-8ff9-4367-ace4-dfa5162359d7} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:60244) (comment: 00855_join_with_array_join.sql) (in query: DROP DATABASE IF EXISTS test_sggp7mfp ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:38:56.909795 [ 4694 ] {450a7293-8ff9-4367-ace4-dfa5162359d7} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:56.952945 [ 4799 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:57.161516 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:57.923627 [ 3903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:58.055183 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:58.232324 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:59.007131 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:59.108427 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:59.287167 [ 4799 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:38:59.918306 [ 9557 ] {3eff340a-a7ee-484d-bfa5-1aff1a62cdf0} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:51204) (comment: 02313_filesystem_cache_seeks.sh) (in query: INSERT INTO test_02313 SELECT * FROM generateRandom('id Int32, val String') LIMIT 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 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*) @ 0x000000003aea17d9 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:38:59.923029 [ 9557 ] {3eff340a-a7ee-484d-bfa5-1aff1a62cdf0} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 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*) @ 0x000000003aea17d9 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:39:00.033107 [ 4799 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:00.114395 [ 3895 ] {e35547d8-e689-4721-b7b7-90ed93bc7d18} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:51238) (comment: 01913_names_of_tuple_literal.sql) (in query: SET enable_analyzer = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000003159b57b 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337550f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e79fb4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:00.116647 [ 3895 ] {e35547d8-e689-4721-b7b7-90ed93bc7d18} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000003159b57b 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337550f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e79fb4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:00.164115 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:00.364463 [ 3895 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:01.089888 [ 4745 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:01.288904 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:01.420568 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:02.148783 [ 3903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:02.384974 [ 3903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:02.593854 [ 3903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:03.041330 [ 3044 ] {} void DB::StorageBuffer::backgroundFlush(): 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/StorageBuffer.cpp:0: DB::StorageBuffer::flushAllBuffers(bool) @ 0x0000000038ddb12c 8. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x0000000038de8318 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038dec4ff 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:03.208159 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:03.472288 [ 4745 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:03.673936 [ 4745 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:04.042192 [ 3043 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/StorageBuffer.cpp:0: DB::StorageBuffer::flushAllBuffers(bool) @ 0x0000000038ddb12c 8. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x0000000038de8318 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038dec4ff 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:04.253729 [ 7759 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:04.526597 [ 3903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:04.716864 [ 3903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:05.312061 [ 3903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:05.585621 [ 4745 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:05.768152 [ 3903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:06.045487 [ 3041 ] {} void DB::StorageBuffer::backgroundFlush(): 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/StorageBuffer.cpp:0: DB::StorageBuffer::flushAllBuffers(bool) @ 0x0000000038ddb12c 8. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x0000000038de8318 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038dec4ff 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:06.365449 [ 4649 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:06.654778 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:06.825186 [ 4649 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:07.198701 [ 4745 ] {95760e07-2a97-44c0-87bb-f0668a62d3e2} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:43856) (comment: 02317_distinct_in_order_optimization_explain.sh) (in query: explain pipeline select distinct 1, b, a from distinct_in_order_explain), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202dea34 6. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039a5dbc5 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003bf2b229 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bf26bba 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003bf26345 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bf3d5b9 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2045: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf42fe0 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be48783 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003beb6da5 14. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:513: DB::InterpreterExplainQuery::executeImpl() @ 0x000000003495cb4c 15. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:0: DB::InterpreterExplainQuery::execute() @ 0x00000000349520a4 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:39:07.200952 [ 4745 ] {95760e07-2a97-44c0-87bb-f0668a62d3e2} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202dea34 6. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039a5dbc5 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003bf2b229 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bf26bba 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003bf26345 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bf3d5b9 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2045: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf42fe0 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be48783 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003beb6da5 14. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:513: DB::InterpreterExplainQuery::executeImpl() @ 0x000000003495cb4c 15. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:0: DB::InterpreterExplainQuery::execute() @ 0x00000000349520a4 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:39:07.420047 [ 4649 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:07.811640 [ 7759 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:07.870970 [ 4649 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:08.049555 [ 3039 ] {} void DB::StorageBuffer::backgroundFlush(): 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/StorageBuffer.cpp:0: DB::StorageBuffer::flushAllBuffers(bool) @ 0x0000000038ddb12c 8. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x0000000038de8318 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038dec4ff 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:08.453149 [ 7759 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:08.718848 [ 4745 ] {170c08ee-b1cb-48c4-b753-7d18bcdb4c9e} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:43984) (comment: 02317_distinct_in_order_optimization_explain.sh) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000003159b57b 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337550f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e79fb4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:08.720870 [ 4745 ] {170c08ee-b1cb-48c4-b753-7d18bcdb4c9e} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000003159b57b 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337550f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e79fb4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:08.936134 [ 7759 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:08.944367 [ 4649 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:09.431347 [ 4649 ] {7d5fab42-3b8b-4271-82c3-4b0ae943dd7a} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44026) (comment: 02317_distinct_in_order_optimization_explain.sh) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000003159b57b 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337550f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e79fb4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:09.433337 [ 4649 ] {7d5fab42-3b8b-4271-82c3-4b0ae943dd7a} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000003159b57b 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337550f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e79fb4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:09.492368 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:09.632071 [ 4841 ] {5fd28b94-61ce-4014-9150-9a4b964504a4} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=778, jobs=749). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44006) (comment: 00398_url_functions.gen.sql) (in query: SELECT domain('newuser:@example.com') AS Host;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:39:09.634389 [ 4841 ] {5fd28b94-61ce-4014-9150-9a4b964504a4} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=778, jobs=749). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:39:10.002630 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:10.003435 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:10.166285 [ 4841 ] {b3b1f0aa-5a0c-4494-93f7-39691917d405} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44066) (comment: 02317_distinct_in_order_optimization_explain.sh) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000003159b57b 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337550f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e79fb4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:10.263528 [ 4841 ] {b3b1f0aa-5a0c-4494-93f7-39691917d405} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000003159b57b 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337550f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e79fb4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:10.507012 [ 7759 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:10.958256 [ 4841 ] {76746cac-eaae-47c2-93e3-b0176f8dbc3c} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44092) (comment: 02317_distinct_in_order_optimization_explain.sh) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000003159b57b 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337550f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e79fb4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:10.962014 [ 4841 ] {76746cac-eaae-47c2-93e3-b0176f8dbc3c} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000003159b57b 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337550f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e79fb4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:11.040028 [ 9453 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:11.100599 [ 6965 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:11.655894 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:11.730233 [ 9453 ] {6376383e-588a-425e-988a-dc08549c02fc} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44130) (comment: 02317_distinct_in_order_optimization_explain.sh) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000003159b57b 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337550f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e79fb4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:11.732603 [ 9453 ] {6376383e-588a-425e-988a-dc08549c02fc} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000003159b57b 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337550f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e79fb4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:12.055496 [ 3051 ] {} void DB::StorageBuffer::backgroundFlush(): 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/StorageBuffer.cpp:0: DB::StorageBuffer::flushAllBuffers(bool) @ 0x0000000038ddb12c 8. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x0000000038de8318 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038dec4ff 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:12.087328 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:12.169563 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:12.440270 [ 9453 ] {0b1e9795-fa02-42db-bcb8-bca41d48990e} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44190) (comment: 02317_distinct_in_order_optimization_explain.sh) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000003159b57b 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337550f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e79fb4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:12.442550 [ 9453 ] {0b1e9795-fa02-42db-bcb8-bca41d48990e} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000003159b57b 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337550f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e79fb4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:12.667174 [ 9678 ] {1c354959-9b18-4d0a-81f6-459be2b490e8} executeQuery: Code: 43. DB::Exception: Argument 'max_width' must not be NaN: In scope SELECT bar((greatCircleAngle(65537, 2, 1, 1) - 1) * 65535, 1048576, 1048577, nan). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44082) (comment: 01621_bar_nan_arguments.sql) (in query: SELECT bar((greatCircleAngle(65537, 2, 1, 1) - 1) * 65535, 1048576, 1048577, nan);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. DB::(anonymous namespace)::FunctionBar::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000bb9275f 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 2025.10.23 23:39:12.668553 [ 9678 ] {1c354959-9b18-4d0a-81f6-459be2b490e8} TCPHandler: Code: 43. DB::Exception: Argument 'max_width' must not be NaN: In scope SELECT bar((greatCircleAngle(65537, 2, 1, 1) - 1) * 65535, 1048576, 1048577, nan). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. DB::(anonymous namespace)::FunctionBar::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000bb9275f 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 2025.10.23 23:39:12.682944 [ 9678 ] {a185afc8-acde-4779-86b7-566fd68a1fad} executeQuery: Code: 43. DB::Exception: Argument 'max_width' must not be NaN: In scope SELECT bar(1, 1, 1, nan). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44082) (comment: 01621_bar_nan_arguments.sql) (in query: select bar(1,1,1,nan);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. DB::(anonymous namespace)::FunctionBar::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000bb9275f 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 2025.10.23 23:39:12.684082 [ 9678 ] {a185afc8-acde-4779-86b7-566fd68a1fad} TCPHandler: Code: 43. DB::Exception: Argument 'max_width' must not be NaN: In scope SELECT bar(1, 1, 1, nan). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. DB::(anonymous namespace)::FunctionBar::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000bb9275f 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 2025.10.23 23:39:12.712012 [ 9453 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:13.123385 [ 7759 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:13.162888 [ 4649 ] {6e078158-f4c7-42f6-9639-50f0a9c08f74} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44198) (comment: 02317_distinct_in_order_optimization_explain.sh) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000003159b57b 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337550f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e79fb4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:13.165317 [ 4649 ] {6e078158-f4c7-42f6-9639-50f0a9c08f74} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000003159b57b 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337550f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e79fb4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:13.240825 [ 7759 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:13.795985 [ 4649 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:14.058589 [ 3049 ] {} void DB::StorageBuffer::backgroundFlush(): 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/StorageBuffer.cpp:0: DB::StorageBuffer::flushAllBuffers(bool) @ 0x0000000038ddb12c 8. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x0000000038de8318 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038dec4ff 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:14.164767 [ 9453 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:14.348956 [ 9453 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:14.884677 [ 6965 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:15.228112 [ 4675 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:15.403602 [ 9453 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:15.841607 [ 4841 ] {ebecb71b-6720-4c4d-a91b-dd58671cf0fe} executeQuery: Code: 36. DB::Exception: Encrypted data is smaller than the size of additional data for AEAD mode, cannot decrypt.: In scope SELECT decrypt('aes-128-gcm', '[HIDDEN]'). (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44244) (comment: 01776_decrypt_aead_size_check.sql) (in query: SELECT decrypt('aes-128-gcm', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. COW::immutable_ptr DB::FunctionDecrypt::doDecrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000000df5a30f 5. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df578e8 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 2025.10.23 23:39:15.842972 [ 4841 ] {ebecb71b-6720-4c4d-a91b-dd58671cf0fe} TCPHandler: Code: 36. DB::Exception: Encrypted data is smaller than the size of additional data for AEAD mode, cannot decrypt.: In scope SELECT decrypt('aes-128-gcm', '[HIDDEN]'). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. COW::immutable_ptr DB::FunctionDecrypt::doDecrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000000df5a30f 5. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df578e8 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 2025.10.23 23:39:15.929537 [ 9453 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:16.317668 [ 4675 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:16.471863 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:16.849198 [ 4675 ] {93aee143-ae5e-4a0f-826e-d731f705625a} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=778, jobs=748). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:34276) (comment: 01802_formatDateTime_DateTime64_century.sql) (in query: SELECT formatDateTime(toDateTime64('2105-12-12 12:12:12', 0, 'Asia/Istanbul'), '%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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:39:16.851330 [ 4675 ] {93aee143-ae5e-4a0f-826e-d731f705625a} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=778, jobs=748). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:39:16.980157 [ 9453 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:17.064709 [ 3046 ] {} void DB::StorageBuffer::backgroundFlush(): 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/StorageBuffer.cpp:0: DB::StorageBuffer::flushAllBuffers(bool) @ 0x0000000038ddb12c 8. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x0000000038de8318 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038dec4ff 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:17.387343 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:17.616460 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:18.041870 [ 9453 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:18.464355 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:18.714792 [ 4675 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:19.068315 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:19.068735 [ 3044 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/StorageBuffer.cpp:0: DB::StorageBuffer::flushAllBuffers(bool) @ 0x0000000038ddb12c 8. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x0000000038de8318 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038dec4ff 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:19.539673 [ 4675 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:19.800444 [ 4675 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:20.191931 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:20.667938 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:20.896815 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:21.131223 [ 3042 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/StorageBuffer.cpp:0: DB::StorageBuffer::flushAllBuffers(bool) @ 0x0000000038ddb12c 8. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x0000000038de8318 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038dec4ff 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:21.273893 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:21.692735 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:21.928227 [ 4799 ] {960dccaf-2e75-46cc-95cf-5d872aed718b} executeQuery: Code: 57. DB::Exception: Table test_11.test already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02899_indexing_by_space_filling_curves.sql) (in query: /* ddl_entry=query-0000000063 */ CREATE TABLE test_11.test UUID '99b7c31c-caf5-4d71-b500-28e2686f091e' (`x` UInt32, `y` UInt32) ENGINE = MergeTree ORDER BY mortonEncode(x, y) SETTINGS index_granularity = 8192, index_granularity_bytes = '1Mi', min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 16, min_bytes_for_full_part_storage = 478617682, compact_parts_max_bytes_to_buffer = 41769197, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 23683038, merge_max_block_size = 10141, old_parts_lifetime = 68., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 6800840725, concurrent_part_removal_threshold = 7, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 54632, primary_key_compress_block_size = 70783), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003395fc9e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000033958fac 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ad726d 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a52a3c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfab2 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:39:21.934694 [ 4799 ] {960dccaf-2e75-46cc-95cf-5d872aed718b} executeQuery: Code: 57. DB::Exception: Table test_11.test already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:34558) (comment: 02899_indexing_by_space_filling_curves.sql) (in query: CREATE TABLE test (`x` UInt32, `y` UInt32) ENGINE = MergeTree ORDER BY mortonEncode(x, y) SETTINGS index_granularity = 8192, index_granularity_bytes = '1Mi', min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 16, min_bytes_for_full_part_storage = 478617682, compact_parts_max_bytes_to_buffer = 41769197, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 23683038, merge_max_block_size = 10141, old_parts_lifetime = 68., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 6800840725, concurrent_part_removal_threshold = 7, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 54632, primary_key_compress_block_size = 70783), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003395fc9e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000033958fac 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ad726d 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a52a3c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfab2 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:39:21.936012 [ 4799 ] {960dccaf-2e75-46cc-95cf-5d872aed718b} TCPHandler: Code: 57. DB::Exception: Table test_11.test already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003395fc9e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000033958fac 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ad726d 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a52a3c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfab2 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:39:21.981129 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:22.340531 [ 4799 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:22.427411 [ 3654 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {26a86919-b755-436d-800b-c04857d425d1::202510_1_79_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 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) @ 0x0000000039c89948 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000003999bfb7 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 @ 0x00000000399942f0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000039d15c04 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&) @ 0x0000000039d20399 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) @ 0x0000000039d1c606 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000396308a4 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x00000000396235dd 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000003963b3e0 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x00000000396504a0 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3c455d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:22.488786 [ 6965 ] {715c20bb-60fc-489a-843b-c332da7f41a7} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:34188) (comment: 02017_bit_shift_left_for_string_integer.sql) (in query: SELECT id as shift_right_bit,'Hello' as arg,bin(bitShiftLeft('Hello', id)) as string_res FROM test_bit_shift_left_string_integer;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:39:22.491534 [ 6965 ] {715c20bb-60fc-489a-843b-c332da7f41a7} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:39:22.570402 [ 4675 ] {0865e8fa-0a77-41b3-8529-d194bf48536f} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:40236) (comment: 02017_bit_shift_left_for_string_integer.sql) (in query: DROP DATABASE IF EXISTS test_zd74mvcg ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:39:22.572347 [ 4675 ] {0865e8fa-0a77-41b3-8529-d194bf48536f} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:22.604824 [ 4799 ] {dc37dec7-d24f-4f94-8955-a914a2fd8f40} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:40240) (comment: 02017_bit_shift_left_for_string_integer.sql) (in query: DROP DATABASE IF EXISTS test_zd74mvcg ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:39:22.606822 [ 4799 ] {dc37dec7-d24f-4f94-8955-a914a2fd8f40} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:22.622188 [ 4675 ] {fa0cc912-5abe-4000-a1d7-01ad2760eed5} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:40246) (comment: 02017_bit_shift_left_for_string_integer.sql) (in query: DROP DATABASE IF EXISTS test_zd74mvcg ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:39:22.624203 [ 4675 ] {fa0cc912-5abe-4000-a1d7-01ad2760eed5} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:22.799046 [ 4799 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:23.071645 [ 4649 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:23.134894 [ 3040 ] {} void DB::StorageBuffer::backgroundFlush(): 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/StorageBuffer.cpp:0: DB::StorageBuffer::flushAllBuffers(bool) @ 0x0000000038ddb12c 8. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x0000000038de8318 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038dec4ff 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:23.386685 [ 4745 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:23.822804 [ 18541 ] {7df97978-7ada-47a6-a807-19648a7e0c67} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:47338) (comment: 02015_shard_crash_clang_12_build.sh) (in query: SELECT count() AS `count()` FROM `test_3`.`local` 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:39:23.825724 [ 18541 ] {7df97978-7ada-47a6-a807-19648a7e0c67} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:39:23.830736 [ 4694 ] {131da049-689d-4c5c-970e-5eda7d6f0a9a} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:34774) (comment: 02015_shard_crash_clang_12_build.sh) (in query: SELECT count() FROM distributed), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002019af32 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000003a7e3e0c 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::Connection::receivePacket() @ 0x000000003a7ff61b 5. ./build_docker/./src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003a8ed7f8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000323566d1 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032355a26 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000032352f12 2025.10.23 23:39:23.846665 [ 4694 ] {131da049-689d-4c5c-970e-5eda7d6f0a9a} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 : 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002019af32 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000003a7e3e0c 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::Connection::receivePacket() @ 0x000000003a7ff61b 5. ./build_docker/./src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003a8ed7f8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000323566d1 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032355a26 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000032352f12 2025.10.23 23:39:23.949057 [ 18541 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:24.038253 [ 4675 ] {d620b894-8056-4845-b286-2028c5d8dfa6} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:40286) (comment: 02907_read_buffer_content_is_cached_multiple_blobs.sql) (in query: DROP DATABASE IF EXISTS test_bj5vtjqe ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:39:24.040564 [ 4675 ] {d620b894-8056-4845-b286-2028c5d8dfa6} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:24.167585 [ 7759 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:24.427920 [ 4745 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:24.596226 [ 9453 ] {b1c3472c-74b0-494b-a6a4-0eecb94c2dbf} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:34858) (comment: 02015_shard_crash_clang_12_build.sh) (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:39:24.599193 [ 9453 ] {b1c3472c-74b0-494b-a6a4-0eecb94c2dbf} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:39:24.666186 [ 7565 ] {16cf8c2d-a0a3-43e0-9740-3818d9a04113} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=778, jobs=757). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:34894) (comment: 02015_shard_crash_clang_12_build.sh) (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:39:24.672054 [ 7565 ] {16cf8c2d-a0a3-43e0-9740-3818d9a04113} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=778, jobs=757). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:39:24.991231 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:25.198318 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:25.321236 [ 4841 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:25.461543 [ 18545 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:25.589206 [ 2903 ] {cada9f22-178d-4c23-8fa5-cffd8ededf03} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:38738) (comment: 02015_shard_crash_clang_12_build.sh) (in query: SELECT count() AS `count()` FROM `test_3`.`local` 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:39:25.592370 [ 2903 ] {cada9f22-178d-4c23-8fa5-cffd8ededf03} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:39:25.598177 [ 4745 ] {35d617a3-0ce5-4b7b-93a7-20ecbf618081} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42436) (comment: 02015_shard_crash_clang_12_build.sh) (in query: SELECT count() FROM distributed), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002019af32 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000003a7e3e0c 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::Connection::receivePacket() @ 0x000000003a7ff61b 5. ./build_docker/./src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003a8ed7f8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000323566d1 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032355a26 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000032352f12 2025.10.23 23:39:25.603036 [ 4745 ] {35d617a3-0ce5-4b7b-93a7-20ecbf618081} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 : 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002019af32 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000003a7e3e0c 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::Connection::receivePacket() @ 0x000000003a7ff61b 5. ./build_docker/./src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003a8ed7f8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000323566d1 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032355a26 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000032352f12 2025.10.23 23:39:25.604559 [ 2904 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:47310, 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x00000000204bfd30 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x00000000204c0cc1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a8112cd 6. DB::ReadBuffer::next() @ 0x00000000095b468f 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000003abd729e 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:25.669540 [ 3895 ] {98dd44b2-6ed5-4dc8-8db2-21ba3dfb3c4a} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=778, jobs=749). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42452) (comment: 02015_shard_crash_clang_12_build.sh) (in query: SELECT count() FROM distributed), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:39:25.673641 [ 3895 ] {98dd44b2-6ed5-4dc8-8db2-21ba3dfb3c4a} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=778, jobs=749). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:39:25.856270 [ 4841 ] {4a4928ea-bd0e-4303-bdf2-3acf649bfed2} executeQuery: Code: 60. DB::Exception: Table test_t2f1gv0x.ghdata does not exist. Maybe you meant test_11.data?. (UNKNOWN_TABLE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42458) (comment: 01825_type_json_ghdata.sh) (in query: INSERT INTO ghdata FORMAT JSONAsObject), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x000000000861dc7f 4. ./build_docker/./src/Databases/IDatabase.cpp:39: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b146ec 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:433: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000003399fc33 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:957: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339b4ac1 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000034b9ec4f 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000034bb99c8 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:25.859951 [ 4841 ] {4a4928ea-bd0e-4303-bdf2-3acf649bfed2} TCPHandler: Code: 60. DB::Exception: Table test_t2f1gv0x.ghdata does not exist. Maybe you meant test_11.data?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x000000000861dc7f 4. ./build_docker/./src/Databases/IDatabase.cpp:39: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b146ec 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:433: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000003399fc33 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:957: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339b4ac1 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000034b9ec4f 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000034bb99c8 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:26.055561 [ 4649 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:26.168352 [ 4841 ] {18bb7193-3d3b-4411-b66c-555baca9896f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42478) (comment: 02015_shard_crash_clang_12_build.sh) (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:39:26.171470 [ 4841 ] {18bb7193-3d3b-4411-b66c-555baca9896f} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:39:26.234611 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:26.238850 [ 3038 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/StorageBuffer.cpp:0: DB::StorageBuffer::flushAllBuffers(bool) @ 0x0000000038ddb12c 8. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x0000000038de8318 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038dec4ff 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:26.285462 [ 4694 ] {5811a958-6597-4163-bb23-74bf53382442} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42538) (comment: 02015_shard_crash_clang_12_build.sh) (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:39:26.372117 [ 4694 ] {5811a958-6597-4163-bb23-74bf53382442} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:39:26.493578 [ 6965 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:26.669157 [ 4675 ] {88f96fc1-ee0c-4ebf-a723-5f37c052bd66} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'ghdata' in scope SELECT count() FROM ghdata WHERE NOT ignore(*). (UNKNOWN_TABLE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42580) (comment: 01825_type_json_ghdata.sh) (in query: SELECT count() FROM ghdata WHERE NOT ignore(*)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa0996d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334eae8a 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003343676d 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 2025.10.23 23:39:26.671487 [ 4675 ] {88f96fc1-ee0c-4ebf-a723-5f37c052bd66} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'ghdata' in scope SELECT count() FROM ghdata WHERE NOT ignore(*). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa0996d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334eae8a 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003343676d 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 2025.10.23 23:39:27.173467 [ 3895 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:27.205954 [ 2903 ] {3182b014-755f-4147-8ca5-edcca5d58472} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=778, jobs=765). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42648) (comment: 02015_shard_crash_clang_12_build.sh) (in query: SELECT count() FROM distributed), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:39:27.209216 [ 2903 ] {3182b014-755f-4147-8ca5-edcca5d58472} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=778, jobs=765). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:39:27.312315 [ 3895 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:27.531020 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:28.017165 [ 4694 ] {0c203347-4629-48cc-a003-f6c0eb2548fd} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=778, jobs=753). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42756) (comment: 02015_shard_crash_clang_12_build.sh) (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:39:28.020111 [ 4694 ] {0c203347-4629-48cc-a003-f6c0eb2548fd} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=778, jobs=753). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:39:28.238514 [ 9453 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:28.242218 [ 3051 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/StorageBuffer.cpp:0: DB::StorageBuffer::flushAllBuffers(bool) @ 0x0000000038ddb12c 8. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x0000000038de8318 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038dec4ff 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:28.377552 [ 3895 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:28.567644 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:28.842146 [ 9557 ] {27da6c06-4002-40bb-949a-7c2ad17afbfb} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:38730) (comment: 02015_shard_crash_clang_12_build.sh) (in query: SELECT count() AS `count()` FROM `test_3`.`local` 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:39:28.845474 [ 9557 ] {27da6c06-4002-40bb-949a-7c2ad17afbfb} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:39:28.872748 [ 4694 ] {875115f7-4dd6-4258-b1b2-8ecc8cc71534} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42882) (comment: 02015_shard_crash_clang_12_build.sh) (in query: SELECT count() FROM distributed), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002019af32 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000003a7e3e0c 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::Connection::receivePacket() @ 0x000000003a7ff61b 5. ./build_docker/./src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003a8ed7f8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000323566d1 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032355a26 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000032352f12 2025.10.23 23:39:28.877760 [ 4694 ] {875115f7-4dd6-4258-b1b2-8ecc8cc71534} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 : 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002019af32 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000003a7e3e0c 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::Connection::receivePacket() @ 0x000000003a7ff61b 5. ./build_docker/./src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003a8ed7f8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000323566d1 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032355a26 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000032352f12 2025.10.23 23:39:29.094632 [ 2904 ] {eeaca138-ea5c-4128-935f-7ee8e2794110} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'ghdata' in scope SELECT data.repo.name, count() AS stars FROM ghdata WHERE data.type = 'WatchEvent' GROUP BY data.repo.name ORDER BY stars DESC, data.repo.name ASC LIMIT 5. (UNKNOWN_TABLE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42910) (comment: 01825_type_json_ghdata.sh) (in query: SELECT data.repo.name, count() AS stars FROM ghdata WHERE data.type = 'WatchEvent' GROUP BY data.repo.name ORDER BY stars DESC, data.repo.name LIMIT 5), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa0996d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334eae8a 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003343676d 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 2025.10.23 23:39:29.098516 [ 2904 ] {eeaca138-ea5c-4128-935f-7ee8e2794110} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'ghdata' in scope SELECT data.repo.name, count() AS stars FROM ghdata WHERE data.type = 'WatchEvent' GROUP BY data.repo.name ORDER BY stars DESC, data.repo.name ASC LIMIT 5. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa0996d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334eae8a 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003343676d 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 2025.10.23 23:39:29.295809 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:29.425687 [ 3895 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:29.616439 [ 4675 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:29.780569 [ 4752 ] {020f70bf-42ee-4df5-a964-8bd86b679434} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:54062). (NETWORK_ERROR) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:54062) (comment: 02015_shard_crash_clang_12_build.sh) (in query: SELECT count() AS `count()` FROM `test_3`.`local` 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:158: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c63a0 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendEndOfStream() @ 0x000000003ac004fe 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd97c9 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:39:29.782356 [ 4752 ] {020f70bf-42ee-4df5-a964-8bd86b679434} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:54062). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c6938 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000003ac2dd9a 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x000000003abff96a 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9aa8 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:29.782656 [ 4752 ] {020f70bf-42ee-4df5-a964-8bd86b679434} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:54062). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:158: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c63a0 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendEndOfStream() @ 0x000000003ac004fe 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd97c9 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:39:29.783188 [ 4752 ] {020f70bf-42ee-4df5-a964-8bd86b679434} TCPHandler: Client has gone away. 2025.10.23 23:39:29.808045 [ 2904 ] {a29ca05b-b9c6-4269-9e82-4b49236cb026} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'ghdata' in scope SELECT data.payload.commits.author.name AS name, count() AS c FROM ghdata ARRAY JOIN data.payload.commits.author.name GROUP BY name ORDER BY c DESC, name ASC LIMIT 5. (UNKNOWN_TABLE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:43014) (comment: 01825_type_json_ghdata.sh) (in query: SELECT data.payload.commits.author.name AS name, count() AS c FROM ghdata ARRAY JOIN data.payload.commits.author.name GROUP BY name ORDER BY c DESC, name LIMIT 5), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa0996d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334eae8a 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003343676d 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 2025.10.23 23:39:29.811984 [ 2904 ] {a29ca05b-b9c6-4269-9e82-4b49236cb026} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'ghdata' in scope SELECT data.payload.commits.author.name AS name, count() AS c FROM ghdata ARRAY JOIN data.payload.commits.author.name GROUP BY name ORDER BY c DESC, name ASC LIMIT 5. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa0996d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334eae8a 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003343676d 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 2025.10.23 23:39:29.974516 [ 9678 ] {342482ac-b645-4e9b-827a-a82ef44a8252} executeQuery: Code: 241. DB::Exception: Memory tracker (for query): fault injected. Would use 1.73 MiB (attempt to allocate chunk of 0 bytes), maximum: 47.68 MiB: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42328) (comment: 01062_pm_all_join_with_block_continuation.sql) (in query: SELECT count(1), uniqExact(n) FROM ( SELECT materialize(1) as k, n FROM numbers(1000000) nums JOIN (SELECT materialize(1) AS k, number n FROM numbers(10)) j USING k);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, String&&, long&, String&&) @ 0x000000002009baa7 4. ./build_docker/./src/Common/MemoryTracker.cpp:284: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002009a3d3 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099272 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:85: CurrentMemoryTracker::check() @ 0x000000001ff7c865 7. ./build_docker/./src/Interpreters/Aggregator.cpp:0: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000033b55571 8. ./build_docker/./src/Interpreters/Aggregator.cpp:0: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000033b6c296 9. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:692: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003b7a34d4 10. ./src/Common/CollectionOfDerived.h:28: DB::AggregatingTransform::work() @ 0x000000003b797254 11. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 17. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:39:29.977891 [ 9678 ] {342482ac-b645-4e9b-827a-a82ef44a8252} TCPHandler: Code: 241. DB::Exception: Memory tracker (for query): fault injected. Would use 1.73 MiB (attempt to allocate chunk of 0 bytes), maximum: 47.68 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, String&&, long&, String&&) @ 0x000000002009baa7 4. ./build_docker/./src/Common/MemoryTracker.cpp:284: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002009a3d3 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099272 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:85: CurrentMemoryTracker::check() @ 0x000000001ff7c865 7. ./build_docker/./src/Interpreters/Aggregator.cpp:0: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000033b55571 8. ./build_docker/./src/Interpreters/Aggregator.cpp:0: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000033b6c296 9. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:692: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003b7a34d4 10. ./src/Common/CollectionOfDerived.h:28: DB::AggregatingTransform::work() @ 0x000000003b797254 11. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 17. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:39:30.316850 [ 18545 ] {8208d63d-8714-4daa-80b3-5fdfaf6a4e65} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:60810) (comment: 02015_shard_crash_clang_12_build.sh) (in query: SELECT count() AS `count()` FROM `test_3`.`local` 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:39:30.319399 [ 18545 ] {8208d63d-8714-4daa-80b3-5fdfaf6a4e65} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:39:30.325265 [ 2904 ] {e4faf8c1-46aa-4359-9549-70fb1025642f} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:43030) (comment: 02015_shard_crash_clang_12_build.sh) (in query: SELECT count() FROM distributed), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002019af32 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000003a7e3e0c 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::Connection::receivePacket() @ 0x000000003a7ff61b 5. ./build_docker/./src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003a8ed7f8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000323566d1 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032355a26 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000032352f12 2025.10.23 23:39:30.328861 [ 2904 ] {e4faf8c1-46aa-4359-9549-70fb1025642f} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 : 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002019af32 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000003a7e3e0c 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::Connection::receivePacket() @ 0x000000003a7ff61b 5. ./build_docker/./src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003a8ed7f8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000323566d1 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032355a26 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000032352f12 2025.10.23 23:39:30.348429 [ 4649 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:30.491952 [ 4649 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:30.543385 [ 18545 ] {0a960f79-ad7e-4ae6-8998-4b03ba9baa6d} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'ghdata' in scope SELECT max(data.payload.pull_request.assignees.size0) FROM ghdata. (UNKNOWN_TABLE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:43098) (comment: 01825_type_json_ghdata.sh) (in query: SELECT max(data.payload.pull_request.assignees.size0) FROM ghdata), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa0996d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334eae8a 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003343676d 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 2025.10.23 23:39:30.561837 [ 18545 ] {0a960f79-ad7e-4ae6-8998-4b03ba9baa6d} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'ghdata' in scope SELECT max(data.payload.pull_request.assignees.size0) FROM ghdata. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa0996d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334eae8a 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003343676d 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 2025.10.23 23:39:30.625599 [ 2904 ] {8bc4b8a8-9cd5-4b7e-9f01-283c664f1224} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:43120) (comment: 02910_object-json-crash-add-column.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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000003159b57b 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337550f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e79fb4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:30.626621 [ 2904 ] {8bc4b8a8-9cd5-4b7e-9f01-283c664f1224} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000003159b57b 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337550f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e79fb4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:30.650514 [ 3895 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:31.183123 [ 2903 ] {27263bc5-50b6-4ccf-9ba9-bdbc2105f376} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:43172) (comment: 02015_shard_crash_clang_12_build.sh) (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:39:31.189917 [ 2903 ] {27263bc5-50b6-4ccf-9ba9-bdbc2105f376} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:39:31.418482 [ 4752 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:31.557711 [ 3895 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:31.681510 [ 3895 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:32.377132 [ 9557 ] {e17ecfcc-356d-4708-a517-1caa35c84b93} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=778, jobs=752). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:60812) (comment: 02015_shard_crash_clang_12_build.sh) (in query: SELECT count() AS `count()` FROM `test_3`.`local` 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:39:32.380093 [ 9557 ] {e17ecfcc-356d-4708-a517-1caa35c84b93} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=778, jobs=752). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:39:32.500757 [ 18541 ] {1292f4b2-8eca-4d9e-a2e1-af1d6e091e9e} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: fault injected (threads=778, jobs=752). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:43338) (comment: 02015_shard_crash_clang_12_build.sh) (in query: SELECT count() FROM distributed), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002019af32 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000003a7e3e0c 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::Connection::receivePacket() @ 0x000000003a7ff61b 5. ./build_docker/./src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003a8ed7f8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000323566d1 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032355a26 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000032352f12 2025.10.23 23:39:32.504757 [ 18541 ] {1292f4b2-8eca-4d9e-a2e1-af1d6e091e9e} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: fault injected (threads=778, jobs=752). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 : 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002019af32 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000003a7e3e0c 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::Connection::receivePacket() @ 0x000000003a7ff61b 5. ./build_docker/./src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003a8ed7f8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000323566d1 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032355a26 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000032352f12 2025.10.23 23:39:32.506134 [ 4745 ] {692dc42c-7bff-446d-acb0-fce8fd065716} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.1]:9000 -> [::ffff:127.0.0.1]:48564). (NETWORK_ERROR) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:48564) (comment: 02015_shard_crash_clang_12_build.sh) (in query: SELECT count() AS `count()` FROM `test_3`.`local` 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:158: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c63a0 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendEndOfStream() @ 0x000000003ac004fe 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd97c9 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:39:32.515890 [ 4745 ] {692dc42c-7bff-446d-acb0-fce8fd065716} 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]:48564). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c6938 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000003ac2dd9a 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x000000003abff96a 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9aa8 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:32.516404 [ 4745 ] {692dc42c-7bff-446d-acb0-fce8fd065716} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.1]:9000 -> [::ffff:127.0.0.1]:48564). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:158: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c63a0 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendEndOfStream() @ 0x000000003ac004fe 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd97c9 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:39:32.517105 [ 4745 ] {692dc42c-7bff-446d-acb0-fce8fd065716} TCPHandler: Client has gone away. 2025.10.23 23:39:32.548071 [ 4649 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:32.693916 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:32.697028 [ 3895 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:33.226302 [ 3536 ] {} test_3.table1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.10.23 23:39:33.226443 [ 3145 ] {} test_3.`02691_drop_column_replicated` (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.10.23 23:39:33.227340 [ 3094 ] {} test_3.rmt (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.10.23 23:39:33.227359 [ 3246 ] {} test_15.r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.10.23 23:39:33.227478 [ 3266 ] {} test_3.`02691_drop_column_replicated` (1045b1a8-f37f-4f75-892a-b44e770b298b): void DB::StorageReplicatedMergeTree::mergeSelectingTask(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/test_3/test/02691_drop_column/replicas/r1/log_pointer. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x0000000030538e6c 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000003cbf6898 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003cbf5ab3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x000000003a0eb80c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:2447: DB::ReplicatedMergeTreeMergePredicate::ReplicatedMergeTreeMergePredicate(DB::ReplicatedMergeTreeQueue&, std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x000000003a15e77f 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1899: DB::ReplicatedMergeTreeQueue::getMergePredicate(std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x000000003a14165c 9. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::mergeSelectingTask() @ 0x00000000388a7cf6 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6fdf 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:33.227895 [ 3379 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02725_start_stop_fetches_test_15/r/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:33.228168 [ 3222 ] {} test_3.rmt (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /test/02253/02253_empty_part_checksums_test_3/rmt/blocks. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x0000000030538e6c 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe8649 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000003cbe7761 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x000000003a061e9e 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x000000003a04fe19 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a041419 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:50: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a03dd98 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003a06697f 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:33.228282 [ 9453 ] {a9ffde09-1547-4ce0-a527-197501eab45a} executeQuery: Code: 999. Coordination::Exception: Coordination error: Connection loss, path /test/db/test_11/max_log_ptr. (KEEPER_EXCEPTION) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:43196) (comment: 03164_materialize_skip_index.sql) (in query: CREATE TABLE t_skip_index_insert (`a` UInt64, `b` UInt64, INDEX idx_a a TYPE minmax GRANULARITY 1, INDEX idx_b b TYPE set(3) GRANULARITY 1) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 4, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 275332815, compact_parts_max_bytes_to_buffer = 311539477, compact_parts_max_granules_to_buffer = 173, compact_parts_merge_max_bytes_to_prefetch_part = 12821195, merge_max_block_size = 22147, old_parts_lifetime = 313., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 7485573942, index_granularity_bytes = 13909373, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 8255, primary_key_compress_block_size = 10668), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x0000000030538e6c 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000003cbf6898 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003cbf5ab3 6. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ad5036 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a52a3c 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfab2 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:39:33.228508 [ 3266 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000003cc8de51 3. ./src/Common/ZooKeeper/IKeeper.h:509: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003cd16a3e 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003cd2369f 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe6e6d 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe5f26 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe84e7 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe81ea 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000003a10064e 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000003889f11d 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f9f 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:33.228647 [ 3379 ] {} test_3.`02691_drop_column_replicated` (1045b1a8-f37f-4f75-892a-b44e770b298b): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000003cc8de51 3. ./src/Common/ZooKeeper/IKeeper.h:509: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003cd16a3e 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1383: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x000000003cd1a472 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x000000003cbf5306 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:610: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x000000003cbf42db 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000003cbf676b 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003cbf5ab3 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x000000003a0eb80c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889e7df 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:33.229003 [ 3222 ] {} test_3.`02691_drop_column_replicated` (1045b1a8-f37f-4f75-892a-b44e770b298b): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000003cc8de51 3. ./src/Common/ZooKeeper/IKeeper.h:509: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003cd16a3e 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003cd2369f 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe6e6d 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe5f26 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe84e7 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe81ea 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000003a10064e 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000003889f11d 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f9f 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:33.229123 [ 3266 ] {} test_3.table1 (b8db3d6a-6199-4d9d-9ab7-f9a99f2d7089): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_3/test_table12/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:33.229312 [ 3379 ] {} test_3.table1 (b8db3d6a-6199-4d9d-9ab7-f9a99f2d7089): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000003cc8de51 3. ./src/Common/ZooKeeper/IKeeper.h:509: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003cd16a3e 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003cd2369f 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe6e6d 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe5f26 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe84e7 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe81ea 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000003a10064e 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000003889f11d 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f9f 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:33.229377 [ 3222 ] {} test_3.rmt (1c58b3d3-3aa3-4fc2-81b4-6ea1ac046ae6): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/02253/02253_empty_part_checksums_test_3/rmt/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:33.230092 [ 3266 ] {} test_3.rmt (1c58b3d3-3aa3-4fc2-81b4-6ea1ac046ae6): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000003cc8de51 3. ./src/Common/ZooKeeper/IKeeper.h:509: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003cd16a3e 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003cd2369f 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe6e6d 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe5f26 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe84e7 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe81ea 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000003a10064e 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000003889f11d 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f9f 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:33.230465 [ 3222 ] {} test_3.rmt (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000003cc8de51 3. ./src/Common/ZooKeeper/IKeeper.h:509: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003cd16a3e 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000003cd20792 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryExistsNoThrow(String const&, std::function) @ 0x000000003cbf3581 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003cbf26a1 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000003cbf3a70 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003cbea871 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000003a0439c9 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a04133c 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:50: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a03dd98 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003a06697f 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 15. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:33.232388 [ 9453 ] {a9ffde09-1547-4ce0-a527-197501eab45a} TCPHandler: Code: 999. Coordination::Exception: Coordination error: Connection loss, path /test/db/test_11/max_log_ptr. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x0000000030538e6c 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000003cbf6898 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003cbf5ab3 6. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ad5036 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a52a3c 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfab2 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:39:33.251839 [ 3046 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/StorageBuffer.cpp:0: DB::StorageBuffer::flushAllBuffers(bool) @ 0x0000000038ddb12c 8. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x0000000038de8318 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038dec4ff 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:33.533635 [ 4694 ] {e2194aee-b3e2-4bee-b745-354d905ee96f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:48574) (comment: 02015_shard_crash_clang_12_build.sh) (in query: SELECT count() AS `count()` FROM `test_3`.`local` 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:39:33.537525 [ 4694 ] {e2194aee-b3e2-4bee-b745-354d905ee96f} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:39:33.544621 [ 7759 ] {442e4204-061e-4465-92e6-3bf93a8fdd84} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:43480) (comment: 02015_shard_crash_clang_12_build.sh) (in query: SELECT count() FROM distributed), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002019af32 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000003a7e3e0c 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::Connection::receivePacket() @ 0x000000003a7ff61b 5. ./build_docker/./src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003a8ed7f8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000323566d1 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032355a26 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000032352f12 2025.10.23 23:39:33.548096 [ 9557 ] {d8efcf81-e8ea-46e2-961b-e65bec0a02aa} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:60814). (NETWORK_ERROR) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:60814) (comment: 02015_shard_crash_clang_12_build.sh) (in query: SELECT count() AS `count()` FROM `test_3`.`local` 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:158: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c63a0 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendEndOfStream() @ 0x000000003ac004fe 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd97c9 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:39:33.549724 [ 9557 ] {d8efcf81-e8ea-46e2-961b-e65bec0a02aa} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:60814). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c6938 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000003ac2dd9a 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x000000003abff96a 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9aa8 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:33.550062 [ 9557 ] {d8efcf81-e8ea-46e2-961b-e65bec0a02aa} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:60814). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:158: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c63a0 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendEndOfStream() @ 0x000000003ac004fe 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd97c9 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:39:33.550677 [ 9557 ] {d8efcf81-e8ea-46e2-961b-e65bec0a02aa} TCPHandler: Client has gone away. 2025.10.23 23:39:33.558836 [ 7759 ] {442e4204-061e-4465-92e6-3bf93a8fdd84} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 : 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002019af32 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000003a7e3e0c 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::Connection::receivePacket() @ 0x000000003a7ff61b 5. ./build_docker/./src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003a8ed7f8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000323566d1 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032355a26 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000032352f12 2025.10.23 23:39:33.645107 [ 9453 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:33.766525 [ 18545 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:33.767065 [ 9453 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:34.723921 [ 18541 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:34.830169 [ 3895 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:34.831128 [ 18541 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:35.255032 [ 3044 ] {} void DB::StorageBuffer::backgroundFlush(): 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/StorageBuffer.cpp:0: DB::StorageBuffer::flushAllBuffers(bool) @ 0x0000000038ddb12c 8. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x0000000038de8318 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038dec4ff 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:35.276926 [ 7652 ] {22bc013c-4638-4cc3-ba9c-8d43fc2c0ad4} executeQuery: Code: 158. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 9.00, current rows: 10.00: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (TOO_MANY_ROWS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:43594) (comment: 01801_approx_total_rows_mergetree_reverse.sql) (in query: select * from data_01801 where key = 0 order by key settings max_rows_to_read=9 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x00000000323602d7 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:24: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000003235fdb0 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x00000000322c9634 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed7438 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:39:35.279478 [ 7652 ] {22bc013c-4638-4cc3-ba9c-8d43fc2c0ad4} TCPHandler: Code: 158. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 9.00, current rows: 10.00: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x00000000323602d7 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:24: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000003235fdb0 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x00000000322c9634 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed7438 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:39:35.335248 [ 7652 ] {76f054c0-2bca-4002-99aa-178844798e7e} executeQuery: Code: 158. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 9.00, current rows: 10.00: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InReverseOrder). (TOO_MANY_ROWS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:43594) (comment: 01801_approx_total_rows_mergetree_reverse.sql) (in query: select * from data_01801 where key = 0 order by key desc settings max_rows_to_read=9 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x00000000323602d7 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:24: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000003235fdb0 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x00000000322c9634 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed7438 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:39:35.415183 [ 7652 ] {76f054c0-2bca-4002-99aa-178844798e7e} TCPHandler: Code: 158. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 9.00, current rows: 10.00: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InReverseOrder). (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x00000000323602d7 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:24: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000003235fdb0 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x00000000322c9634 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed7438 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:39:35.845496 [ 4752 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:35.888057 [ 9557 ] {ed7266cb-5ed6-490f-a4f6-d80fe8db8fcd} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:60826) (comment: 02015_shard_crash_clang_12_build.sh) (in query: SELECT count() AS `count()` FROM `test_3`.`local` 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:39:35.890917 [ 9557 ] {ed7266cb-5ed6-490f-a4f6-d80fe8db8fcd} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:39:35.897931 [ 7759 ] {d607caea-d877-453b-9a1c-332b1bbb5cd0} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:39018) (comment: 02015_shard_crash_clang_12_build.sh) (in query: SELECT count() FROM distributed), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002019af32 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000003a7e3e0c 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::Connection::receivePacket() @ 0x000000003a7ff61b 5. ./build_docker/./src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003a8ed7f8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000323566d1 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032355a26 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000032352f12 2025.10.23 23:39:35.901537 [ 7759 ] {d607caea-d877-453b-9a1c-332b1bbb5cd0} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 : 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002019af32 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000003a7e3e0c 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::Connection::receivePacket() @ 0x000000003a7ff61b 5. ./build_docker/./src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003a8ed7f8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000323566d1 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032355a26 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000032352f12 2025.10.23 23:39:35.921950 [ 4752 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:35.995471 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:36.946471 [ 4752 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:37.021805 [ 4752 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:37.046151 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:37.245252 [ 4694 ] {8a17a637-fe69-4cde-930b-d8cb813df8af} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:48590) (comment: 02015_shard_crash_clang_12_build.sh) (in query: SELECT count() AS `count()` FROM `test_3`.`local` 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:39:37.252370 [ 4694 ] {8a17a637-fe69-4cde-930b-d8cb813df8af} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:39:37.258327 [ 4752 ] {7dc9ee2f-aa25-4aca-9afa-cf60051ef1f3} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:39248) (comment: 02015_shard_crash_clang_12_build.sh) (in query: SELECT count() FROM distributed), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002019af32 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000003a7e3e0c 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::Connection::receivePacket() @ 0x000000003a7ff61b 5. ./build_docker/./src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003a8ed7f8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000323566d1 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032355a26 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000032352f12 2025.10.23 23:39:37.286222 [ 4649 ] {4d8da735-b51b-4e16-b094-18de1bcdd7bc} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:44840). (NETWORK_ERROR) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:44840) (comment: 02015_shard_crash_clang_12_build.sh) (in query: SELECT count() AS `count()` FROM `test_3`.`local` 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:158: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c63a0 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendEndOfStream() @ 0x000000003ac004fe 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd97c9 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:39:37.288178 [ 4649 ] {4d8da735-b51b-4e16-b094-18de1bcdd7bc} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:44840). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c6938 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000003ac2dd9a 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x000000003abff96a 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9aa8 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:37.288501 [ 4649 ] {4d8da735-b51b-4e16-b094-18de1bcdd7bc} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:44840). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:158: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c63a0 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendEndOfStream() @ 0x000000003ac004fe 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd97c9 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:39:37.288804 [ 4752 ] {7dc9ee2f-aa25-4aca-9afa-cf60051ef1f3} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 : 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002019af32 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000003a7e3e0c 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::Connection::receivePacket() @ 0x000000003a7ff61b 5. ./build_docker/./src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003a8ed7f8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000323566d1 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032355a26 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000032352f12 2025.10.23 23:39:37.289059 [ 4649 ] {4d8da735-b51b-4e16-b094-18de1bcdd7bc} TCPHandler: Client has gone away. 2025.10.23 23:39:37.393026 [ 4745 ] {78d6467d-e139-460f-bd36-7b1dca6978eb} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:39286) (comment: 02015_shard_crash_clang_12_build.sh) (in query: SELECT count() FROM distributed), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:39:37.424602 [ 4745 ] {78d6467d-e139-460f-bd36-7b1dca6978eb} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:39:37.598375 [ 3933 ] {d25c95bc-084e-47ab-ae2c-ea3bf9cf7f22} 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]:47304). (NETWORK_ERROR) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:47304) (comment: 02015_shard_crash_clang_12_build.sh) (in query: SELECT count() AS `count()` FROM `test_3`.`local` 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c6938 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000003ac044bd 6. ./contrib/llvm-project/libcxx/include/__mutex_base:253: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfbb15 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 2025.10.23 23:39:37.601689 [ 3933 ] {d25c95bc-084e-47ab-ae2c-ea3bf9cf7f22} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:47304). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c6938 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000003ac2dd9a 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x000000003abff96a 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9aa8 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:37.602013 [ 3933 ] {d25c95bc-084e-47ab-ae2c-ea3bf9cf7f22} 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]:47304). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c6938 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000003ac044bd 6. ./contrib/llvm-project/libcxx/include/__mutex_base:253: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfbb15 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 2025.10.23 23:39:37.602555 [ 3933 ] {d25c95bc-084e-47ab-ae2c-ea3bf9cf7f22} TCPHandler: Client has gone away. 2025.10.23 23:39:38.001764 [ 18545 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:38.084089 [ 4752 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:38.103035 [ 3895 ] {1ab22e08-4849-4fb1-a7ca-a1e296ebfde2} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:39364) (comment: 02015_shard_crash_clang_12_build.sh) (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:39:38.107981 [ 3895 ] {1ab22e08-4849-4fb1-a7ca-a1e296ebfde2} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:39:38.130271 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:38.294436 [ 3041 ] {} void DB::StorageBuffer::backgroundFlush(): 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/StorageBuffer.cpp:0: DB::StorageBuffer::flushAllBuffers(bool) @ 0x0000000038ddb12c 8. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x0000000038de8318 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038dec4ff 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:38.452558 [ 4799 ] {a9d74229-4862-4821-986b-0b2451364fef} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.1]:9000 -> [::ffff:127.0.0.1]:38732). (NETWORK_ERROR) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:38732) (comment: 02015_shard_crash_clang_12_build.sh) (in query: SELECT count() AS `count()` FROM `test_3`.`local` 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:158: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c63a0 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000003ac044bd 6. ./contrib/llvm-project/libcxx/include/__mutex_base:253: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfbb15 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 2025.10.23 23:39:38.455910 [ 4799 ] {a9d74229-4862-4821-986b-0b2451364fef} 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]:38732). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c6938 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000003ac2dd9a 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x000000003abff96a 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9aa8 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:38.456336 [ 4799 ] {a9d74229-4862-4821-986b-0b2451364fef} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.1]:9000 -> [::ffff:127.0.0.1]:38732). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:158: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c63a0 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000003ac044bd 6. ./contrib/llvm-project/libcxx/include/__mutex_base:253: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfbb15 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 2025.10.23 23:39:38.456991 [ 4799 ] {a9d74229-4862-4821-986b-0b2451364fef} TCPHandler: Client has gone away. 2025.10.23 23:39:39.047673 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:39.167444 [ 18541 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:39.261399 [ 4752 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:39.826419 [ 3933 ] {156b5c91-7040-4c31-8893-f5c1b5f46331} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:39610) (comment: 02015_shard_crash_clang_12_build.sh) (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:39:39.830339 [ 3933 ] {156b5c91-7040-4c31-8893-f5c1b5f46331} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:39:39.925836 [ 18545 ] {8b1e2f63-10ef-481d-8141-b33c54743c6e} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed: While processing SELECT id FROM `03161_table` WHERE f AND ((NOT f) OR f) SETTINGS convert_query_to_cnf = 1, optimize_using_constraints = 1, enable_analyzer = 1. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:39380) (comment: 03161_cnf_reduction.sql) (in query: EXPLAIN SYNTAX SELECT id FROM 03161_table WHERE f AND (NOT(f) OR f) SETTINGS convert_query_to_cnf = 1, optimize_using_constraints = 1, enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000003159b57b 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337550f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::executeForCurrentContext(bool) @ 0x0000000034e7a8ad 9. ./src/Interpreters/InterpreterSetQuery.h:14: DB::InterpreterSelectQuery::initSettings() @ 0x0000000034c055da 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:418: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000034bec999 11. ./contrib/llvm-project/libcxx/include/optional:260: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000034bead07 12. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034bea511 13. ./contrib/llvm-project/libcxx/include/vector:438: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x000000003496e67f 14. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x000000003496f156 15. ./src/Interpreters/InDepthNodeVisitor.h:0: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x000000003496f161 16. ./src/Interpreters/InDepthNodeVisitor.h:0: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x000000003496f161 17. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::InterpreterExplainQuery::executeImpl() @ 0x000000003495d6ff 18. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:0: DB::InterpreterExplainQuery::execute() @ 0x00000000349520a4 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 2025.10.23 23:39:39.929639 [ 18545 ] {8b1e2f63-10ef-481d-8141-b33c54743c6e} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed: While processing SELECT id FROM `03161_table` WHERE f AND ((NOT f) OR f) SETTINGS convert_query_to_cnf = 1, optimize_using_constraints = 1, enable_analyzer = 1. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000003159b57b 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337550f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::executeForCurrentContext(bool) @ 0x0000000034e7a8ad 9. ./src/Interpreters/InterpreterSetQuery.h:14: DB::InterpreterSelectQuery::initSettings() @ 0x0000000034c055da 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:418: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000034bec999 11. ./contrib/llvm-project/libcxx/include/optional:260: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000034bead07 12. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034bea511 13. ./contrib/llvm-project/libcxx/include/vector:438: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x000000003496e67f 14. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x000000003496f156 15. ./src/Interpreters/InDepthNodeVisitor.h:0: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x000000003496f161 16. ./src/Interpreters/InDepthNodeVisitor.h:0: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x000000003496f161 17. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::InterpreterExplainQuery::executeImpl() @ 0x000000003495d6ff 18. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:0: DB::InterpreterExplainQuery::execute() @ 0x00000000349520a4 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 2025.10.23 23:39:40.109907 [ 4752 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:40.252901 [ 4752 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:40.450904 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:41.146584 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:41.305497 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:41.564688 [ 4799 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:42.211418 [ 4745 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:42.382122 [ 4752 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:42.450113 [ 18541 ] {ef6eac52-cb14-4cf6-a792-9811f6263618} DatabaseReplicated (test_11): It's not recommended to explicitly specify zookeeper_path and replica_name in ReplicatedMergeTree arguments 2025.10.23 23:39:42.451526 [ 18541 ] {ef6eac52-cb14-4cf6-a792-9811f6263618} executeQuery: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:40018) (comment: 01277_alter_rename_column_constraint_zookeeper_long.sql) (in query: CREATE TABLE table_for_rename1 ( date Date, key UInt64, value1 String, value2 String, value3 String, CONSTRAINT cs_value1 CHECK toInt64(value1) < toInt64(value2), CONSTRAINT cs_value2 CHECK toInt64(value2) < toInt64(value3) ) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/test_01277/test_for_rename', '1') PARTITION BY date ORDER BY key;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000032a4a38c 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000032a4fcff 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a51799 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfab2 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:42.453053 [ 18541 ] {ef6eac52-cb14-4cf6-a792-9811f6263618} TCPHandler: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000032a4a38c 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000032a4fcff 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a51799 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfab2 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:42.496231 [ 18540 ] {8eb9287b-b781-49ad-8b63-1d4e5efd710c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=779, jobs=772). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:38770) (comment: 02015_shard_crash_clang_12_build.sh) (in query: SELECT count() AS `count()` FROM `test_3`.`local` 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:39:42.499082 [ 18540 ] {8eb9287b-b781-49ad-8b63-1d4e5efd710c} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=779, jobs=772). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:39:42.505788 [ 4694 ] {f833a746-80f6-4f9a-a620-cf1d2c55a4e4} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Cannot schedule a task: fault injected (threads=779, jobs=772). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:40048) (comment: 02015_shard_crash_clang_12_build.sh) (in query: SELECT count() FROM distributed), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002019af32 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000003a7e3e0c 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::Connection::receivePacket() @ 0x000000003a7ff61b 5. ./build_docker/./src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003a8ed7f8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000323566d1 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032355a26 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000032352f12 2025.10.23 23:39:42.509901 [ 4694 ] {f833a746-80f6-4f9a-a620-cf1d2c55a4e4} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Cannot schedule a task: fault injected (threads=779, jobs=772). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 : 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002019af32 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000003a7e3e0c 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::Connection::receivePacket() @ 0x000000003a7ff61b 5. ./build_docker/./src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003a8ed7f8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000323566d1 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032355a26 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000032352f12 2025.10.23 23:39:42.682861 [ 18541 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:43.267230 [ 18541 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:43.486121 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:43.723535 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:44.089991 [ 18545 ] {552dcf0e-53f0-4ec2-b5a8-23b39b983a63} 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]:44856). (NETWORK_ERROR) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:44856) (comment: 02015_shard_crash_clang_12_build.sh) (in query: SELECT count() AS `count()` FROM `test_3`.`local` 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c6938 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileInfo(DB::ProfileInfo const&) @ 0x000000003ac0e495 6. ./build_docker/./src/Server/TCPHandler.cpp:1165: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfc070 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 2025.10.23 23:39:44.094588 [ 18545 ] {552dcf0e-53f0-4ec2-b5a8-23b39b983a63} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:44856). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c6938 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000003ac2dd9a 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x000000003abff96a 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9aa8 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:44.095070 [ 18545 ] {552dcf0e-53f0-4ec2-b5a8-23b39b983a63} 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]:44856). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c6938 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileInfo(DB::ProfileInfo const&) @ 0x000000003ac0e495 6. ./build_docker/./src/Server/TCPHandler.cpp:1165: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfc070 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 2025.10.23 23:39:44.095919 [ 18545 ] {552dcf0e-53f0-4ec2-b5a8-23b39b983a63} TCPHandler: Client has gone away. 2025.10.23 23:39:44.158932 [ 18540 ] {2673bc92-907e-4085-8268-d65db49d21e6} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:40248) (comment: 02015_shard_crash_clang_12_build.sh) (in query: SELECT count() FROM distributed), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:39:44.163976 [ 18540 ] {2673bc92-907e-4085-8268-d65db49d21e6} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:39:44.233560 [ 18545 ] {72775f21-3647-49e8-ae56-e07f6966423a} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=779, jobs=753). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:40268) (comment: 02015_shard_crash_clang_12_build.sh) (in query: SELECT count() FROM distributed), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:39:44.236427 [ 18545 ] {72775f21-3647-49e8-ae56-e07f6966423a} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=779, jobs=753). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:39:44.307373 [ 3895 ] {63ccccfd-c3ee-4b4a-9ab4-cf6ef61fc32c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=779, jobs=750). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:40284) (comment: 02015_shard_crash_clang_12_build.sh) (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:39:44.311209 [ 3895 ] {63ccccfd-c3ee-4b4a-9ab4-cf6ef61fc32c} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=779, jobs=750). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:39:44.345399 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:44.524973 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:44.798972 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:44.976263 [ 4745 ] {e9c2d402-15f6-47f3-baaf-60ccf5ec2fc0} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=779, jobs=750). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:40076) (comment: 02226_low_cardinality_text_bloom_filter_index.sql) (in query: SELECT 'lc_ngram';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:39:44.980206 [ 4745 ] {e9c2d402-15f6-47f3-baaf-60ccf5ec2fc0} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=779, jobs=750). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:39:45.375405 [ 3050 ] {} void DB::StorageBuffer::backgroundFlush(): 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/StorageBuffer.cpp:0: DB::StorageBuffer::flushAllBuffers(bool) @ 0x0000000038ddb12c 8. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x0000000038de8318 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038dec4ff 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:45.454146 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:45.613820 [ 4745 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:45.798191 [ 4675 ] {916ec246-d716-4a0b-abe7-a383451235e3} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:44846) (comment: 02015_shard_crash_clang_12_build.sh) (in query: SELECT count() AS `count()` FROM `test_3`.`local` 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:39:45.801264 [ 4675 ] {916ec246-d716-4a0b-abe7-a383451235e3} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:39:45.813180 [ 18545 ] {97f967c2-34b0-47e1-91df-5aa0610f7ed7} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37994) (comment: 02015_shard_crash_clang_12_build.sh) (in query: SELECT count() FROM distributed), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002019af32 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000003a7e3e0c 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::Connection::receivePacket() @ 0x000000003a7ff61b 5. ./build_docker/./src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003a8ed7f8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000323566d1 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032355a26 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000032352f12 2025.10.23 23:39:45.817579 [ 18545 ] {97f967c2-34b0-47e1-91df-5aa0610f7ed7} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 : 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002019af32 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000003a7e3e0c 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::Connection::receivePacket() @ 0x000000003a7ff61b 5. ./build_docker/./src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003a8ed7f8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000323566d1 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032355a26 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000032352f12 2025.10.23 23:39:45.822211 [ 18542 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:51040, 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x00000000204bfd30 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x00000000204c0cc1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a8112cd 6. DB::ReadBuffer::next() @ 0x00000000095b468f 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000003abd729e 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:45.861706 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:46.376961 [ 3049 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/StorageBuffer.cpp:0: DB::StorageBuffer::flushAllBuffers(bool) @ 0x0000000038ddb12c 8. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x0000000038de8318 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038dec4ff 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:46.533682 [ 18541 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:46.684335 [ 4745 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:46.999855 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:47.587481 [ 4752 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:47.819165 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:48.019231 [ 9557 ] {fd17ad22-9ea3-4097-b2da-9be9c0f0ca4e} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38064) (comment: 02710_aggregation_nested_map_ip_uuid.sql) (in query: SELECT * FROM summing_table ORDER BY id, ip4Map.value, ip4Map.total, ip6Map.value, ip6Map.total, uuidMap.value, uuidMap.total;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202dea34 6. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039a5dbc5 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003bf2b229 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bf26bba 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003bf26345 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bf3d5b9 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2045: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf42fe0 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be48783 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003beb6da5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034cf5e6d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034cf5881 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:39:48.021618 [ 9557 ] {fd17ad22-9ea3-4097-b2da-9be9c0f0ca4e} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202dea34 6. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039a5dbc5 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003bf2b229 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bf26bba 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003bf26345 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bf3d5b9 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2045: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf42fe0 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be48783 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003beb6da5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034cf5e6d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034cf5881 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:39:48.064336 [ 18541 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:48.207926 [ 3895 ] {d591cb2d-7a48-47fc-b53a-9e09dba4639c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38340) (comment: 02015_shard_crash_clang_12_build.sh) (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:39:48.210617 [ 3895 ] {d591cb2d-7a48-47fc-b53a-9e09dba4639c} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:39:48.638140 [ 4675 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:48.846109 [ 4752 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:49.196029 [ 3895 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:49.444820 [ 9678 ] {de1660fb-a68a-4ce1-afea-9cfe8a026d6d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=779, jobs=755). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:38416) (comment: 02015_shard_crash_clang_12_build.sh) (in query: SELECT count() AS `count()` FROM `test_3`.`local` 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:39:49.448149 [ 9678 ] {de1660fb-a68a-4ce1-afea-9cfe8a026d6d} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=779, jobs=755). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:39:49.456696 [ 18540 ] {dfb5a716-36d1-445b-83cd-7585014a7fa5} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Cannot schedule a task: fault injected (threads=779, jobs=755). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38504) (comment: 02015_shard_crash_clang_12_build.sh) (in query: SELECT count() FROM distributed), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002019af32 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000003a7e3e0c 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::Connection::receivePacket() @ 0x000000003a7ff61b 5. ./build_docker/./src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003a8ed7f8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000323566d1 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032355a26 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000032352f12 2025.10.23 23:39:49.460948 [ 4694 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:37534, 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x00000000204bfd30 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x00000000204c0cc1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a8112cd 6. DB::ReadBuffer::next() @ 0x00000000095b468f 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000003abd729e 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:49.461309 [ 18540 ] {dfb5a716-36d1-445b-83cd-7585014a7fa5} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Cannot schedule a task: fault injected (threads=779, jobs=755). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 : 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002019af32 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000003a7e3e0c 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::Connection::receivePacket() @ 0x000000003a7ff61b 5. ./build_docker/./src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003a8ed7f8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000323566d1 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032355a26 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000032352f12 2025.10.23 23:39:49.716271 [ 18545 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:49.971994 [ 18545 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:50.332046 [ 18541 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:50.494558 [ 3933 ] {89cdead4-ef0b-4527-8cf7-89a41a3aa3d3} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=779, jobs=752). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38638) (comment: 02015_shard_crash_clang_12_build.sh) (in query: SELECT count() FROM distributed), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:39:50.499092 [ 3933 ] {89cdead4-ef0b-4527-8cf7-89a41a3aa3d3} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=779, jobs=752). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:39:50.965622 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:51.024550 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:51.036034 [ 4745 ] {2cc35595-dfc2-42e2-acb0-ccc4e6278d11} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38702) (comment: 02015_shard_crash_clang_12_build.sh) (in query: SELECT count() FROM distributed), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:39:51.039966 [ 4745 ] {2cc35595-dfc2-42e2-acb0-ccc4e6278d11} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:39:51.446488 [ 4675 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:52.053747 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:52.094249 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:52.171185 [ 4841 ] {086303fc-c349-45ea-84a7-6be3cd760cbb} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:48560) (comment: 02015_shard_crash_clang_12_build.sh) (in query: SELECT count() AS `count()` FROM `test_3`.`local` 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:39:52.174464 [ 4841 ] {086303fc-c349-45ea-84a7-6be3cd760cbb} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:39:52.180730 [ 18540 ] {3b64215a-e800-4379-83e1-19b6c8aae58d} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38864) (comment: 02015_shard_crash_clang_12_build.sh) (in query: SELECT count() FROM distributed), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002019af32 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000003a7e3e0c 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::Connection::receivePacket() @ 0x000000003a7ff61b 5. ./build_docker/./src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003a8ed7f8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000323566d1 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032355a26 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000032352f12 2025.10.23 23:39:52.184279 [ 18540 ] {3b64215a-e800-4379-83e1-19b6c8aae58d} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 : 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002019af32 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000003a7e3e0c 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::Connection::receivePacket() @ 0x000000003a7ff61b 5. ./build_docker/./src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003a8ed7f8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000323566d1 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032355a26 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000032352f12 2025.10.23 23:39:52.389111 [ 3043 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=4). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/StorageBuffer.cpp:0: DB::StorageBuffer::flushAllBuffers(bool) @ 0x0000000038ddb12c 8. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x0000000038de8318 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038dec4ff 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:52.389754 [ 3933 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:38882, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x00000000204bfd30 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x00000000204c0cc1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a8112cd 6. DB::ReadBuffer::next() @ 0x00000000095b468f 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000003abd729e 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:52.396054 [ 2904 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:38842, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x00000000204bfd30 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x00000000204c0cc1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a8112cd 6. DB::ReadBuffer::next() @ 0x00000000095b468f 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000003abd729e 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:52.410860 [ 9678 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:38858, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x00000000204bfd30 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x00000000204c0cc1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a8112cd 6. DB::ReadBuffer::next() @ 0x00000000095b468f 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000003abd729e 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:52.430996 [ 4752 ] {520fac8a-6863-44af-aedd-cb0dee3962b2} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:38894). (NETWORK_ERROR) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38894) (comment: 02015_shard_crash_clang_12_build.sh) (in query: SELECT count() FROM distributed), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c6938 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileInfo(DB::ProfileInfo const&) @ 0x000000003ac0e495 6. ./build_docker/./src/Server/TCPHandler.cpp:1165: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfc070 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 2025.10.23 23:39:52.435373 [ 4752 ] {520fac8a-6863-44af-aedd-cb0dee3962b2} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:38894). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c6938 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000003ac2dd9a 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x000000003abff96a 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9aa8 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:52.436109 [ 4752 ] {520fac8a-6863-44af-aedd-cb0dee3962b2} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:38894). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c6938 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileInfo(DB::ProfileInfo const&) @ 0x000000003ac0e495 6. ./build_docker/./src/Server/TCPHandler.cpp:1165: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfc070 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 2025.10.23 23:39:52.436835 [ 4752 ] {520fac8a-6863-44af-aedd-cb0dee3962b2} TCPHandler: Client has gone away. 2025.10.23 23:39:52.539457 [ 18541 ] {c20e4898-e37a-482a-a087-b29a6df00f1c} executeQuery: Code: 344. DB::Exception: CREATE AS SELECT is not supported with Replicated databases. Consider using separate CREATE and INSERT queries. (SUPPORT_IS_DISABLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38772) (comment: 02933_replicated_database_forbid_create_as_select.sh) (in query: CREATE TABLE test_11_db.test2 (`id` UInt64) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 36880, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 0, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 492874024, compact_parts_max_granules_to_buffer = 73, compact_parts_merge_max_bytes_to_prefetch_part = 473326, merge_max_block_size = 19664, old_parts_lifetime = 365., prefer_fetch_merged_part_size_threshold = 7536065615, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 3648593517, index_granularity_bytes = 29705827, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 51707, primary_key_compress_block_size = 28286 AS SELECT 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1508: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348d24fb 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 2025.10.23 23:39:52.542212 [ 18541 ] {c20e4898-e37a-482a-a087-b29a6df00f1c} TCPHandler: Code: 344. DB::Exception: CREATE AS SELECT is not supported with Replicated databases. Consider using separate CREATE and INSERT queries. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1508: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348d24fb 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 2025.10.23 23:39:52.546788 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:53.129785 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:53.161834 [ 18541 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:53.489792 [ 4675 ] {7a371ead-62a7-43d2-b4b1-210a3e0cd232} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.1]:9000 -> [::ffff:127.0.0.1]:38436). (NETWORK_ERROR) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:38436) (comment: 02015_shard_crash_clang_12_build.sh) (in query: SELECT count() AS `count()` FROM `test_3`.`local` 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:158: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c63a0 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileEvents() @ 0x000000003ac13c7b 6. ./build_docker/./src/Server/TCPHandler.cpp:1170: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfc0b6 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 2025.10.23 23:39:53.493161 [ 4675 ] {7a371ead-62a7-43d2-b4b1-210a3e0cd232} 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]:38436). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c6938 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000003ac2dd9a 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x000000003abff96a 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9aa8 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:53.493467 [ 4675 ] {7a371ead-62a7-43d2-b4b1-210a3e0cd232} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.1]:9000 -> [::ffff:127.0.0.1]:38436). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:158: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c63a0 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileEvents() @ 0x000000003ac13c7b 6. ./build_docker/./src/Server/TCPHandler.cpp:1170: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfc0b6 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 2025.10.23 23:39:53.493960 [ 4675 ] {7a371ead-62a7-43d2-b4b1-210a3e0cd232} TCPHandler: Client has gone away. 2025.10.23 23:39:53.586747 [ 18541 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:54.029589 [ 2904 ] {f5cc798e-8760-4cff-ac5d-4f8d4b3862f9} executeQuery: Code: 344. DB::Exception: CREATE with POPULATE is not supported with Replicated databases. Consider using separate CREATE and INSERT queries. Alternatively, you can enable 'database_replicated_allow_heavy_create' setting to allow this operation, use with caution. (SUPPORT_IS_DISABLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38958) (comment: 02933_replicated_database_forbid_create_as_select.sh) (in query: CREATE MATERIALIZED VIEW test_11_db.test_mv2 (id UInt64) ENGINE = ReplicatedMergeTree ORDER BY id POPULATE AS SELECT 1 AS 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348d2aeb 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 2025.10.23 23:39:54.032950 [ 2904 ] {f5cc798e-8760-4cff-ac5d-4f8d4b3862f9} TCPHandler: Code: 344. DB::Exception: CREATE with POPULATE is not supported with Replicated databases. Consider using separate CREATE and INSERT queries. Alternatively, you can enable 'database_replicated_allow_heavy_create' setting to allow this operation, use with caution. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348d2aeb 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 2025.10.23 23:39:54.212403 [ 4752 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:54.221616 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:54.659385 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:55.237537 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:55.264080 [ 18541 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:55.721691 [ 4752 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:56.270772 [ 4752 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:56.349195 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:56.782303 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:56.815433 [ 18541 ] {b8c31100-af51-45b0-a3e2-5c3b539f291b} executeQuery: Code: 344. DB::Exception: CREATE AS SELECT is not supported with Replicated databases. Consider using separate CREATE and INSERT queries. (SUPPORT_IS_DISABLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37024) (comment: 02933_replicated_database_forbid_create_as_select.sh) (in query: CREATE TABLE test_11_db.test2 (`id` UInt64) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 36880, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 0, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 492874024, compact_parts_max_granules_to_buffer = 73, compact_parts_merge_max_bytes_to_prefetch_part = 473326, merge_max_block_size = 19664, old_parts_lifetime = 365., prefer_fetch_merged_part_size_threshold = 7536065615, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 3648593517, index_granularity_bytes = 29705827, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 51707, primary_key_compress_block_size = 28286 AS SELECT 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1508: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348d24fb 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 2025.10.23 23:39:56.818146 [ 18541 ] {b8c31100-af51-45b0-a3e2-5c3b539f291b} TCPHandler: Code: 344. DB::Exception: CREATE AS SELECT is not supported with Replicated databases. Consider using separate CREATE and INSERT queries. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1508: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348d24fb 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 2025.10.23 23:39:57.334621 [ 18541 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:57.422913 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:57.549740 [ 2904 ] {96cd07b7-5cc8-46df-8d5a-263eb6537944} executeQuery: Code: 344. DB::Exception: CREATE AS SELECT is not supported with Replicated databases. Consider using separate CREATE and INSERT queries. (SUPPORT_IS_DISABLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37060) (comment: 02933_replicated_database_forbid_create_as_select.sh) (in query: CREATE TABLE test_11_db.test2 (`id` UInt64) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 36880, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 0, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 492874024, compact_parts_max_granules_to_buffer = 73, compact_parts_merge_max_bytes_to_prefetch_part = 473326, merge_max_block_size = 19664, old_parts_lifetime = 365., prefer_fetch_merged_part_size_threshold = 7536065615, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 3648593517, index_granularity_bytes = 29705827, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 51707, primary_key_compress_block_size = 28286 AS SELECT 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1508: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348d24fb 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 2025.10.23 23:39:57.552186 [ 2904 ] {96cd07b7-5cc8-46df-8d5a-263eb6537944} TCPHandler: Code: 344. DB::Exception: CREATE AS SELECT is not supported with Replicated databases. Consider using separate CREATE and INSERT queries. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1508: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348d24fb 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 2025.10.23 23:39:57.873340 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:58.386006 [ 18541 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:58.400117 [ 3038 ] {} void DB::StorageBuffer::backgroundFlush(): 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/StorageBuffer.cpp:0: DB::StorageBuffer::flushAllBuffers(bool) @ 0x0000000038ddb12c 8. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x0000000038de8318 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038dec4ff 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:58.468359 [ 18541 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:58.922293 [ 18541 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:59.469013 [ 18541 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:59.563662 [ 4752 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:39:59.992179 [ 4752 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:00.563151 [ 4752 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:00.716793 [ 4752 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:01.050617 [ 18541 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:01.097690 [ 3385 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:01.645722 [ 4752 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:01.797788 [ 4752 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:02.098397 [ 3061 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:02.140264 [ 4752 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:02.246506 [ 9453 ] {25519d08-a118-486a-a5ef-7c85aa00c8fe} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:43632) (comment: 01651_lc_insert_tiny_log_2.sql) (in query: select sum(length(arr)), sum(num) from perf_lc_num;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:40:02.252823 [ 9453 ] {25519d08-a118-486a-a5ef-7c85aa00c8fe} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:40:02.430117 [ 18541 ] {45e36739-c35e-4048-b097-92ab96770aed} executeQuery: Code: 1. DB::Exception: Lambda must have arguments and body. (UNSUPPORTED_METHOD) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37192) (comment: 02181_sql_user_defined_functions_invalid_lambda.sql) (in query: CREATE FUNCTION 02181_invalid_lambda AS lambda(((x * 2) AS x_doubled) + x_doubled);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Functions/UserDefined/UserDefinedSQLFunctionFactory.cpp:56: DB::UserDefinedSQLFunctionFactory::checkCanBeRegistered(std::shared_ptr const&, String const&, DB::IAST const&) @ 0x000000003c2103ff 5. ./build_docker/./src/Functions/UserDefined/UserDefinedSQLFunctionFactory.cpp:0: DB::UserDefinedSQLFunctionFactory::registerFunction(std::shared_ptr const&, String const&, std::shared_ptr, bool, bool) @ 0x000000003c211418 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterCreateFunctionQuery::execute() @ 0x0000000035a66775 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:40:02.431328 [ 18541 ] {45e36739-c35e-4048-b097-92ab96770aed} TCPHandler: Code: 1. DB::Exception: Lambda must have arguments and body. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Functions/UserDefined/UserDefinedSQLFunctionFactory.cpp:56: DB::UserDefinedSQLFunctionFactory::checkCanBeRegistered(std::shared_ptr const&, String const&, DB::IAST const&) @ 0x000000003c2103ff 5. ./build_docker/./src/Functions/UserDefined/UserDefinedSQLFunctionFactory.cpp:0: DB::UserDefinedSQLFunctionFactory::registerFunction(std::shared_ptr const&, String const&, std::shared_ptr, bool, bool) @ 0x000000003c211418 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterCreateFunctionQuery::execute() @ 0x0000000035a66775 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:40:02.442769 [ 18541 ] {c6435e35-c213-49a5-aece-cca7de93373f} executeQuery: Code: 1. DB::Exception: Lambda must have arguments and body. (UNSUPPORTED_METHOD) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37192) (comment: 02181_sql_user_defined_functions_invalid_lambda.sql) (in query: CREATE FUNCTION 02181_invalid_lambda AS lambda(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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Functions/UserDefined/UserDefinedSQLFunctionFactory.cpp:56: DB::UserDefinedSQLFunctionFactory::checkCanBeRegistered(std::shared_ptr const&, String const&, DB::IAST const&) @ 0x000000003c2103ff 5. ./build_docker/./src/Functions/UserDefined/UserDefinedSQLFunctionFactory.cpp:0: DB::UserDefinedSQLFunctionFactory::registerFunction(std::shared_ptr const&, String const&, std::shared_ptr, bool, bool) @ 0x000000003c211418 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterCreateFunctionQuery::execute() @ 0x0000000035a66775 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:40:02.443844 [ 18541 ] {c6435e35-c213-49a5-aece-cca7de93373f} TCPHandler: Code: 1. DB::Exception: Lambda must have arguments and body. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Functions/UserDefined/UserDefinedSQLFunctionFactory.cpp:56: DB::UserDefinedSQLFunctionFactory::checkCanBeRegistered(std::shared_ptr const&, String const&, DB::IAST const&) @ 0x000000003c2103ff 5. ./build_docker/./src/Functions/UserDefined/UserDefinedSQLFunctionFactory.cpp:0: DB::UserDefinedSQLFunctionFactory::registerFunction(std::shared_ptr const&, String const&, std::shared_ptr, bool, bool) @ 0x000000003c211418 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterCreateFunctionQuery::execute() @ 0x0000000035a66775 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:40:02.453608 [ 18541 ] {ac6f4059-92eb-4bb1-863c-8b72a0299081} executeQuery: Code: 1. DB::Exception: Lambda must have arguments and body. (UNSUPPORTED_METHOD) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37192) (comment: 02181_sql_user_defined_functions_invalid_lambda.sql) (in query: CREATE FUNCTION 02181_invalid_lambda AS lambda();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Functions/UserDefined/UserDefinedSQLFunctionFactory.cpp:56: DB::UserDefinedSQLFunctionFactory::checkCanBeRegistered(std::shared_ptr const&, String const&, DB::IAST const&) @ 0x000000003c2103ff 5. ./build_docker/./src/Functions/UserDefined/UserDefinedSQLFunctionFactory.cpp:0: DB::UserDefinedSQLFunctionFactory::registerFunction(std::shared_ptr const&, String const&, std::shared_ptr, bool, bool) @ 0x000000003c211418 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterCreateFunctionQuery::execute() @ 0x0000000035a66775 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:40:02.454505 [ 18541 ] {ac6f4059-92eb-4bb1-863c-8b72a0299081} TCPHandler: Code: 1. DB::Exception: Lambda must have arguments and body. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Functions/UserDefined/UserDefinedSQLFunctionFactory.cpp:56: DB::UserDefinedSQLFunctionFactory::checkCanBeRegistered(std::shared_ptr const&, String const&, DB::IAST const&) @ 0x000000003c2103ff 5. ./build_docker/./src/Functions/UserDefined/UserDefinedSQLFunctionFactory.cpp:0: DB::UserDefinedSQLFunctionFactory::registerFunction(std::shared_ptr const&, String const&, std::shared_ptr, bool, bool) @ 0x000000003c211418 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterCreateFunctionQuery::execute() @ 0x0000000035a66775 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:40:02.464978 [ 18541 ] {47e76145-fae0-4adc-b9b1-1b9386c388ce} executeQuery: Code: 1. DB::Exception: Lambda must have arguments and body. (UNSUPPORTED_METHOD) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37192) (comment: 02181_sql_user_defined_functions_invalid_lambda.sql) (in query: CREATE FUNCTION 02181_invalid_lambda AS lambda(tuple(x)) --{serverError 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Functions/UserDefined/UserDefinedSQLFunctionFactory.cpp:56: DB::UserDefinedSQLFunctionFactory::checkCanBeRegistered(std::shared_ptr const&, String const&, DB::IAST const&) @ 0x000000003c2103ff 5. ./build_docker/./src/Functions/UserDefined/UserDefinedSQLFunctionFactory.cpp:0: DB::UserDefinedSQLFunctionFactory::registerFunction(std::shared_ptr const&, String const&, std::shared_ptr, bool, bool) @ 0x000000003c211418 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterCreateFunctionQuery::execute() @ 0x0000000035a66775 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:40:02.465858 [ 18541 ] {47e76145-fae0-4adc-b9b1-1b9386c388ce} TCPHandler: Code: 1. DB::Exception: Lambda must have arguments and body. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Functions/UserDefined/UserDefinedSQLFunctionFactory.cpp:56: DB::UserDefinedSQLFunctionFactory::checkCanBeRegistered(std::shared_ptr const&, String const&, DB::IAST const&) @ 0x000000003c2103ff 5. ./build_docker/./src/Functions/UserDefined/UserDefinedSQLFunctionFactory.cpp:0: DB::UserDefinedSQLFunctionFactory::registerFunction(std::shared_ptr const&, String const&, std::shared_ptr, bool, bool) @ 0x000000003c211418 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterCreateFunctionQuery::execute() @ 0x0000000035a66775 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:40:02.665860 [ 18541 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:02.913639 [ 18541 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:03.099047 [ 3188 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:03.195041 [ 4675 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:03.409265 [ 3048 ] {} void DB::StorageBuffer::backgroundFlush(): 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/StorageBuffer.cpp:0: DB::StorageBuffer::flushAllBuffers(bool) @ 0x0000000038ddb12c 8. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x0000000038de8318 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038dec4ff 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:03.705378 [ 4675 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:04.050035 [ 18541 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:04.100033 [ 3248 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:04.246909 [ 4675 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:04.740504 [ 4675 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:05.100765 [ 3297 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:05.119603 [ 4675 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:05.327371 [ 4675 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:05.413993 [ 3046 ] {} void DB::StorageBuffer::backgroundFlush(): 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/StorageBuffer.cpp:0: DB::StorageBuffer::flushAllBuffers(bool) @ 0x0000000038ddb12c 8. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x0000000038de8318 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038dec4ff 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:05.831293 [ 18541 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:06.101425 [ 3273 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:06.203665 [ 18541 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:06.415541 [ 3045 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/StorageBuffer.cpp:0: DB::StorageBuffer::flushAllBuffers(bool) @ 0x0000000038ddb12c 8. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x0000000038de8318 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038dec4ff 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:06.447016 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:06.818329 [ 4675 ] {6c7e3b4b-8cea-45a8-8279-637990e6f164} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:53710) (comment: 00386_enum_in_pk.sql) (in query: SELECT cityHash64(groupArray(x)) FROM enum_pk WHERE 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:40:06.822763 [ 4675 ] {6c7e3b4b-8cea-45a8-8279-637990e6f164} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:40:06.885982 [ 4752 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:06.954320 [ 18541 ] {c15dd3ca-256f-4046-8c99-18c3ff4b6d34} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:47034) (comment: 00386_enum_in_pk.sql) (in query: DROP DATABASE IF EXISTS test_tlye9hqx ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:40:06.966180 [ 18541 ] {c15dd3ca-256f-4046-8c99-18c3ff4b6d34} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:07.102119 [ 3408 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:07.277306 [ 4752 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:07.417749 [ 3044 ] {} void DB::StorageBuffer::backgroundFlush(): 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/StorageBuffer.cpp:0: DB::StorageBuffer::flushAllBuffers(bool) @ 0x0000000038ddb12c 8. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x0000000038de8318 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038dec4ff 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:07.520507 [ 4752 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:07.934853 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:08.102862 [ 3347 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:08.351270 [ 4675 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:08.419352 [ 3043 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=4). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/StorageBuffer.cpp:0: DB::StorageBuffer::flushAllBuffers(bool) @ 0x0000000038ddb12c 8. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x0000000038de8318 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038dec4ff 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:08.580321 [ 4675 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:08.981532 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:09.103518 [ 3289 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:09.376278 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:09.421285 [ 3042 ] {} void DB::StorageBuffer::backgroundFlush(): 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/StorageBuffer.cpp:0: DB::StorageBuffer::flushAllBuffers(bool) @ 0x0000000038ddb12c 8. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x0000000038de8318 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038dec4ff 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:09.666327 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:10.032036 [ 4675 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:10.104133 [ 3172 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:10.414696 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:10.873367 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:11.076557 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:11.104772 [ 3228 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:11.489904 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:11.977230 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:12.105450 [ 3513 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:12.124781 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:12.632832 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:13.050083 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:13.106165 [ 3252 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:13.194907 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:13.830386 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:14.106849 [ 3248 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:14.173244 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:14.217457 [ 18540 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:14.332302 [ 13706 ] {} ZooKeeperClient: Code: 999. Coordination::Exception: Session expired (fault injected on recv). (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000003a21d8b1 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEES0_NS_5ErrorEOS5_ @ 0x000000003cd2cd64 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1660: Coordination::ZooKeeper::maybeInjectRecvFault() @ 0x000000003cd156a2 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveEvent() @ 0x000000003cd1207c 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveThread() @ 0x000000003cd109b9 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl> const&, zkutil::ZooKeeperArgs const&, std::shared_ptr)::$_1>(Coordination::ZooKeeper::ZooKeeper(std::vector> const&, zkutil::ZooKeeperArgs const&, std::shared_ptr)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003cd2940f 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:14.334048 [ 3389 ] {} test_3.table1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.10.23 23:40:14.334121 [ 3095 ] {} test_3.`02691_drop_column_replicated` (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.10.23 23:40:14.334244 [ 3365 ] {} test_3.rmt (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.10.23 23:40:14.334450 [ 3452 ] {} test_15.r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.10.23 23:40:14.334987 [ 3374 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02725_start_stop_fetches_test_15/r/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:14.335131 [ 3413 ] {} test_3.rmt (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /test/02253/02253_empty_part_checksums_test_3/rmt/async_blocks. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x0000000030538e6c 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe8649 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000003cbe7761 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x000000003a061e9e 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x000000003a04fe19 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:165: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a04156e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:50: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a03dd98 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003a06697f 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:14.335363 [ 3179 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:14.335644 [ 3474 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000003cc8de51 3. ./src/Common/ZooKeeper/IKeeper.h:509: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003cd16a3e 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003cd2369f 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe6e6d 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe5f26 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe84e7 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe81ea 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000003a10064e 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000003889f11d 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f9f 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:14.335671 [ 3117 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000003cc8de51 3. ./src/Common/ZooKeeper/IKeeper.h:509: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003cd16a3e 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003cd2369f 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe6e6d 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe5f26 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe84e7 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe81ea 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000003a10064e 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000003889f11d 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f9f 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:14.998608 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:15.108313 [ 3261 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:15.263591 [ 18540 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:15.336469 [ 3436 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:15.343228 [ 4745 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:16.068060 [ 18540 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:16.109141 [ 3116 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:16.203584 [ 3085 ] {} test_3.table1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.10.23 23:40:16.203916 [ 3374 ] {} test_3.`02691_drop_column_replicated` (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.10.23 23:40:16.204101 [ 3413 ] {} test_3.rmt (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.10.23 23:40:16.204470 [ 3474 ] {} test_15.r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.10.23 23:40:16.204965 [ 3117 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02725_start_stop_fetches_test_15/r/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:16.205371 [ 3310 ] {} test_3.rmt (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Session expired (fault injected on send). (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000003a21d8b1 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEES0_NS_5ErrorEOS5_ @ 0x000000003cd2cd64 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1654: Coordination::ZooKeeper::maybeInjectSendFault() @ 0x000000003cd17122 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003cd165e8 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000003cd20792 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryExistsNoThrow(String const&, std::function) @ 0x000000003cbf3581 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003cbf26a1 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000003cbf3a70 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003cbea871 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000003a0439c9 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a04133c 13. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:50: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a03dd98 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003a06697f 15. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 17. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:16.206473 [ 3561 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000003cc8de51 3. ./src/Common/ZooKeeper/IKeeper.h:509: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003cd16a3e 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003cd2369f 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe6e6d 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe5f26 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe84e7 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe81ea 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000003a10064e 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000003889f11d 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f9f 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:16.301807 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:16.337331 [ 3502 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:16.469154 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:16.600357 [ 7565 ] {050560c3-f200-406e-b2ec-b2d3f8941dc2} executeQuery: Poco::Exception. Code: 1000, e.code() = 0, Timeout: connect timed out: 128.0.0.1:8123 (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:53980) (comment: 02044_url_glob_parallel_connection_refused.sh) (in query: SELECT * FROM url('http://128.0.0.{1..10}:8123/?query=SELECT+sleep(1)', TSV, 'x UInt8')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, String const&, int) @ 0x00000000403edbad 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:0: Poco::TimeoutException::TimeoutException(String const&, String const&, int) @ 0x00000000403f634e 2. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:145: Poco::Net::SocketImpl::connect(Poco::Net::SocketAddress const&, Poco::Timespan const&) @ 0x0000000040619968 3. ./build_docker/./base/poco/Net/src/StreamSocket.cpp:85: Poco::Net::StreamSocket::connect(Poco::Net::SocketAddress const&, Poco::Timespan const&) @ 0x00000000406256ce 4. ./base/poco/Net/include/Poco/Net/Socket.h:422: Poco::Net::HTTPSession::connect(Poco::Net::SocketAddress const&) @ 0x00000000405b79a8 5. ./build_docker/./base/poco/Net/src/HTTPClientSession.cpp:459: Poco::Net::HTTPClientSession::reconnect() @ 0x00000000405759fe 6. ./build_docker/./src/Common/HTTPConnectionPool.cpp:0: DB::EndpointConnectionPool::prepareNewConnection(DB::ConnectionTimeouts const&) @ 0x0000000020747707 7. ./build_docker/./src/Common/HTTPConnectionPool.cpp:0: DB::EndpointConnectionPool::getConnection(DB::ConnectionTimeouts const&) @ 0x00000000207441de 8. ./build_docker/./src/IO/HTTPCommon.cpp:0: DB::makeHTTPSession(DB::HTTPConnectionGroupType, Poco::URI const&, DB::ConnectionTimeouts const&, DB::ProxyConfiguration const&) @ 0x00000000209793f4 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:265: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb28e3 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 11. ./src/IO/ReadWriteBufferFromHTTP.h:52: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbbed 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000020bad484 14. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:755: DB::ReadWriteBufferFromHTTP::getFileInfo() @ 0x0000000020bacade 15. ./contrib/llvm-project/libcxx/include/optional:344: DB::ReadWriteBufferFromHTTP::tryGetLastModificationTime() @ 0x0000000020bbb76b 16. ./build_docker/./src/Storages/StorageURL.cpp:0: bool std::__function::__policy_invoker::__call_impl> ()>>, String const&, std::function>&)>, String const&, std::optional const&, String, std::shared_ptr const&, unsigned long, DB::ConnectionTimeouts const&, DB::CompressionMethod, unsigned long, std::vector> const&, std::vector, std::allocator>> const&, bool, bool)::$_0, bool ()>>(std::__function::__policy_storage const*) @ 0x0000000038cacec8 17. ./build_docker/./src/Storages/StorageURL.cpp:422: DB::StorageURLSource::generate() @ 0x0000000038c81b6a 18. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae71153 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 2025.10.23 23:40:16.604148 [ 7565 ] {050560c3-f200-406e-b2ec-b2d3f8941dc2} TCPHandler: Code: 1000. DB::Exception: Timeout: connect timed out: 128.0.0.1:8123. (POCO_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, String const&, int) @ 0x00000000403edbad 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:0: Poco::TimeoutException::TimeoutException(String const&, String const&, int) @ 0x00000000403f634e 2. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:145: Poco::Net::SocketImpl::connect(Poco::Net::SocketAddress const&, Poco::Timespan const&) @ 0x0000000040619968 3. ./build_docker/./base/poco/Net/src/StreamSocket.cpp:85: Poco::Net::StreamSocket::connect(Poco::Net::SocketAddress const&, Poco::Timespan const&) @ 0x00000000406256ce 4. ./base/poco/Net/include/Poco/Net/Socket.h:422: Poco::Net::HTTPSession::connect(Poco::Net::SocketAddress const&) @ 0x00000000405b79a8 5. ./build_docker/./base/poco/Net/src/HTTPClientSession.cpp:459: Poco::Net::HTTPClientSession::reconnect() @ 0x00000000405759fe 6. ./build_docker/./src/Common/HTTPConnectionPool.cpp:0: DB::EndpointConnectionPool::prepareNewConnection(DB::ConnectionTimeouts const&) @ 0x0000000020747707 7. ./build_docker/./src/Common/HTTPConnectionPool.cpp:0: DB::EndpointConnectionPool::getConnection(DB::ConnectionTimeouts const&) @ 0x00000000207441de 8. ./build_docker/./src/IO/HTTPCommon.cpp:0: DB::makeHTTPSession(DB::HTTPConnectionGroupType, Poco::URI const&, DB::ConnectionTimeouts const&, DB::ProxyConfiguration const&) @ 0x00000000209793f4 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:265: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb28e3 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 11. ./src/IO/ReadWriteBufferFromHTTP.h:52: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbbed 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000020bad484 14. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:755: DB::ReadWriteBufferFromHTTP::getFileInfo() @ 0x0000000020bacade 15. ./contrib/llvm-project/libcxx/include/optional:344: DB::ReadWriteBufferFromHTTP::tryGetLastModificationTime() @ 0x0000000020bbb76b 16. ./build_docker/./src/Storages/StorageURL.cpp:0: bool std::__function::__policy_invoker::__call_impl> ()>>, String const&, std::function>&)>, String const&, std::optional const&, String, std::shared_ptr const&, unsigned long, DB::ConnectionTimeouts const&, DB::CompressionMethod, unsigned long, std::vector> const&, std::vector, std::allocator>> const&, bool, bool)::$_0, bool ()>>(std::__function::__policy_storage const*) @ 0x0000000038cacec8 17. ./build_docker/./src/Storages/StorageURL.cpp:422: DB::StorageURLSource::generate() @ 0x0000000038c81b6a 18. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae71153 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 2025.10.23 23:40:17.109912 [ 3484 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:17.120778 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:17.338335 [ 3349 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:17.358836 [ 4745 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:17.449859 [ 7652 ] {0f47574f-e519-4287-ad78-250679fe163d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:40208) (comment: 02971_analyzer_remote_id.sh) (in query: CREATE TABLE test_37o6qwl7.x ENGINE = MergeTree ORDER BY number SETTINGS index_granularity = 24406, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 48, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 224935956, compact_parts_max_granules_to_buffer = 142, compact_parts_merge_max_bytes_to_prefetch_part = 8699329, merge_max_block_size = 14866, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10602320325, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 1924508720, index_granularity_bytes = 28854920, concurrent_part_removal_threshold = 71, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 49716, primary_key_compress_block_size = 10903 AS SELECT * FROM numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 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*) @ 0x000000003aea17d9 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:40:17.453016 [ 7652 ] {0f47574f-e519-4287-ad78-250679fe163d} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 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*) @ 0x000000003aea17d9 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:40:17.577424 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:18.110988 [ 3099 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:18.189579 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:18.339466 [ 3257 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:18.518060 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:18.531330 [ 9678 ] {786517b0-c8a3-4e4c-a54d-cabbf68e7b9d} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:41662) (comment: 02971_analyzer_remote_id.sh) (in query: DROP DATABASE IF EXISTS test_37o6qwl7 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:40:18.555933 [ 9678 ] {786517b0-c8a3-4e4c-a54d-cabbf68e7b9d} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:18.768778 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:19.113131 [ 3497 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:19.256907 [ 4745 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:19.317147 [ 18540 ] {c5c86463-3319-4374-ab52-20808b950ded} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=8, jobs=8). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:40180) (comment: 02044_url_glob_parallel_connection_refused.sh) (in query: SELECT * FROM url('http://128.0.0.{1..10}:8123/?query=SELECT+sleep(1)', TSV, 'x UInt8')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:40:19.322601 [ 18540 ] {c5c86463-3319-4374-ab52-20808b950ded} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:40:19.340873 [ 3056 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:19.583997 [ 4745 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:19.821001 [ 4745 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:20.113926 [ 3352 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:20.303581 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:20.341713 [ 3394 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:20.507051 [ 3047 ] {} void DB::StorageBuffer::backgroundFlush(): 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/StorageBuffer.cpp:0: DB::StorageBuffer::flushAllBuffers(bool) @ 0x0000000038ddb12c 8. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x0000000038de8318 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038dec4ff 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:20.660035 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:21.035301 [ 18545 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:21.114641 [ 3106 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:21.342387 [ 3241 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:21.463238 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:21.509202 [ 9343 ] {} StorageBuffer (test_3.mt_buffer_00158): Destination table test_3.mt_00158 doesn't exist. Block of data is discarded. 2025.10.23 23:40:21.717457 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:22.069521 [ 9678 ] {59b7799c-be2a-44fc-9e3a-ba28a23957f7} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:41684) (comment: 00688_low_cardinality_syntax.sql) (in query: DROP DATABASE IF EXISTS test_5gdsvinc ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:40:22.072402 [ 9678 ] {59b7799c-be2a-44fc-9e3a-ba28a23957f7} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:22.115437 [ 3347 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:22.141184 [ 18545 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:22.168657 [ 4745 ] {d9396ce3-d49f-4930-b338-3c6052d63497} executeQuery: Poco::Exception. Code: 1000, e.code() = 0, Timeout: connect timed out: 128.0.0.1:8123 (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:40310) (comment: 02044_url_glob_parallel_connection_refused.sh) (in query: SELECT * FROM url('http://128.0.0.{1..10}:8123/?query=SELECT+sleep(1)', TSV, 'x UInt8')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, String const&, int) @ 0x00000000403edbad 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:0: Poco::TimeoutException::TimeoutException(String const&, String const&, int) @ 0x00000000403f634e 2. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:145: Poco::Net::SocketImpl::connect(Poco::Net::SocketAddress const&, Poco::Timespan const&) @ 0x0000000040619968 3. ./build_docker/./base/poco/Net/src/StreamSocket.cpp:85: Poco::Net::StreamSocket::connect(Poco::Net::SocketAddress const&, Poco::Timespan const&) @ 0x00000000406256ce 4. ./base/poco/Net/include/Poco/Net/Socket.h:422: Poco::Net::HTTPSession::connect(Poco::Net::SocketAddress const&) @ 0x00000000405b79a8 5. ./build_docker/./base/poco/Net/src/HTTPClientSession.cpp:459: Poco::Net::HTTPClientSession::reconnect() @ 0x00000000405759fe 6. ./build_docker/./src/Common/HTTPConnectionPool.cpp:0: DB::EndpointConnectionPool::prepareNewConnection(DB::ConnectionTimeouts const&) @ 0x0000000020747707 7. ./build_docker/./src/Common/HTTPConnectionPool.cpp:0: DB::EndpointConnectionPool::getConnection(DB::ConnectionTimeouts const&) @ 0x00000000207441de 8. ./build_docker/./src/IO/HTTPCommon.cpp:0: DB::makeHTTPSession(DB::HTTPConnectionGroupType, Poco::URI const&, DB::ConnectionTimeouts const&, DB::ProxyConfiguration const&) @ 0x00000000209793f4 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:265: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb28e3 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 11. ./src/IO/ReadWriteBufferFromHTTP.h:52: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbbed 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000020bad484 14. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:755: DB::ReadWriteBufferFromHTTP::getFileInfo() @ 0x0000000020bacade 15. ./contrib/llvm-project/libcxx/include/optional:344: DB::ReadWriteBufferFromHTTP::tryGetLastModificationTime() @ 0x0000000020bbb76b 16. ./build_docker/./src/Storages/StorageURL.cpp:0: bool std::__function::__policy_invoker::__call_impl> ()>>, String const&, std::function>&)>, String const&, std::optional const&, String, std::shared_ptr const&, unsigned long, DB::ConnectionTimeouts const&, DB::CompressionMethod, unsigned long, std::vector> const&, std::vector, std::allocator>> const&, bool, bool)::$_0, bool ()>>(std::__function::__policy_storage const*) @ 0x0000000038cacec8 17. ./build_docker/./src/Storages/StorageURL.cpp:422: DB::StorageURLSource::generate() @ 0x0000000038c81b6a 18. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae71153 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 2025.10.23 23:40:22.173710 [ 4745 ] {d9396ce3-d49f-4930-b338-3c6052d63497} TCPHandler: Code: 1000. DB::Exception: Timeout: connect timed out: 128.0.0.1:8123. (POCO_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, String const&, int) @ 0x00000000403edbad 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:0: Poco::TimeoutException::TimeoutException(String const&, String const&, int) @ 0x00000000403f634e 2. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:145: Poco::Net::SocketImpl::connect(Poco::Net::SocketAddress const&, Poco::Timespan const&) @ 0x0000000040619968 3. ./build_docker/./base/poco/Net/src/StreamSocket.cpp:85: Poco::Net::StreamSocket::connect(Poco::Net::SocketAddress const&, Poco::Timespan const&) @ 0x00000000406256ce 4. ./base/poco/Net/include/Poco/Net/Socket.h:422: Poco::Net::HTTPSession::connect(Poco::Net::SocketAddress const&) @ 0x00000000405b79a8 5. ./build_docker/./base/poco/Net/src/HTTPClientSession.cpp:459: Poco::Net::HTTPClientSession::reconnect() @ 0x00000000405759fe 6. ./build_docker/./src/Common/HTTPConnectionPool.cpp:0: DB::EndpointConnectionPool::prepareNewConnection(DB::ConnectionTimeouts const&) @ 0x0000000020747707 7. ./build_docker/./src/Common/HTTPConnectionPool.cpp:0: DB::EndpointConnectionPool::getConnection(DB::ConnectionTimeouts const&) @ 0x00000000207441de 8. ./build_docker/./src/IO/HTTPCommon.cpp:0: DB::makeHTTPSession(DB::HTTPConnectionGroupType, Poco::URI const&, DB::ConnectionTimeouts const&, DB::ProxyConfiguration const&) @ 0x00000000209793f4 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:265: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb28e3 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 11. ./src/IO/ReadWriteBufferFromHTTP.h:52: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbbed 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000020bad484 14. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:755: DB::ReadWriteBufferFromHTTP::getFileInfo() @ 0x0000000020bacade 15. ./contrib/llvm-project/libcxx/include/optional:344: DB::ReadWriteBufferFromHTTP::tryGetLastModificationTime() @ 0x0000000020bbb76b 16. ./build_docker/./src/Storages/StorageURL.cpp:0: bool std::__function::__policy_invoker::__call_impl> ()>>, String const&, std::function>&)>, String const&, std::optional const&, String, std::shared_ptr const&, unsigned long, DB::ConnectionTimeouts const&, DB::CompressionMethod, unsigned long, std::vector> const&, std::vector, std::allocator>> const&, bool, bool)::$_0, bool ()>>(std::__function::__policy_storage const*) @ 0x0000000038cacec8 17. ./build_docker/./src/Storages/StorageURL.cpp:422: DB::StorageURLSource::generate() @ 0x0000000038c81b6a 18. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae71153 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 2025.10.23 23:40:22.343395 [ 3392 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:22.511637 [ 9339 ] {} StorageBuffer (test_3.mt_buffer_00158): Destination table test_3.mt_00158 doesn't exist. Block of data is discarded. 2025.10.23 23:40:22.562480 [ 4745 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:22.837219 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:23.116117 [ 3341 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:23.196883 [ 4745 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:23.375437 [ 3933 ] {698897bf-342a-472f-8bf1-58b29a247fc1} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:41698) (comment: 00688_low_cardinality_syntax.sql) (in query: DROP DATABASE IF EXISTS test_5gdsvinc ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000003494763c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 13. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 14. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 21. ? @ 0x00007f100c857ac3 22. ? @ 0x00007f100c8e9850 2025.10.23 23:40:23.378601 [ 3933 ] {698897bf-342a-472f-8bf1-58b29a247fc1} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000003494763c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 13. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 14. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 21. ? @ 0x00007f100c857ac3 22. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:23.404886 [ 3319 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:23.592477 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:23.913636 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:24.117106 [ 3452 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:24.240632 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:24.405800 [ 3177 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:24.624712 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:24.930852 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:25.011668 [ 18545 ] {7dfc4a25-67a4-40db-9a40-86c441db4b4c} executeQuery: Poco::Exception. Code: 1000, e.code() = 0, Timeout: connect timed out: 128.0.0.1:8123 (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:40412) (comment: 02044_url_glob_parallel_connection_refused.sh) (in query: SELECT * FROM url('http://128.0.0.{1..10}:8123/?query=SELECT+sleep(1)', TSV, 'x UInt8')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, String const&, int) @ 0x00000000403edbad 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:0: Poco::TimeoutException::TimeoutException(String const&, String const&, int) @ 0x00000000403f634e 2. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:145: Poco::Net::SocketImpl::connect(Poco::Net::SocketAddress const&, Poco::Timespan const&) @ 0x0000000040619968 3. ./build_docker/./base/poco/Net/src/StreamSocket.cpp:85: Poco::Net::StreamSocket::connect(Poco::Net::SocketAddress const&, Poco::Timespan const&) @ 0x00000000406256ce 4. ./base/poco/Net/include/Poco/Net/Socket.h:422: Poco::Net::HTTPSession::connect(Poco::Net::SocketAddress const&) @ 0x00000000405b79a8 5. ./build_docker/./base/poco/Net/src/HTTPClientSession.cpp:459: Poco::Net::HTTPClientSession::reconnect() @ 0x00000000405759fe 6. ./build_docker/./src/Common/HTTPConnectionPool.cpp:0: DB::EndpointConnectionPool::prepareNewConnection(DB::ConnectionTimeouts const&) @ 0x0000000020747707 7. ./build_docker/./src/Common/HTTPConnectionPool.cpp:0: DB::EndpointConnectionPool::getConnection(DB::ConnectionTimeouts const&) @ 0x00000000207441de 8. ./build_docker/./src/IO/HTTPCommon.cpp:0: DB::makeHTTPSession(DB::HTTPConnectionGroupType, Poco::URI const&, DB::ConnectionTimeouts const&, DB::ProxyConfiguration const&) @ 0x00000000209793f4 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:265: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb28e3 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 11. ./src/IO/ReadWriteBufferFromHTTP.h:52: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbbed 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000020bad484 14. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:755: DB::ReadWriteBufferFromHTTP::getFileInfo() @ 0x0000000020bacade 15. ./contrib/llvm-project/libcxx/include/optional:344: DB::ReadWriteBufferFromHTTP::tryGetLastModificationTime() @ 0x0000000020bbb76b 16. ./build_docker/./src/Storages/StorageURL.cpp:0: bool std::__function::__policy_invoker::__call_impl> ()>>, String const&, std::function>&)>, String const&, std::optional const&, String, std::shared_ptr const&, unsigned long, DB::ConnectionTimeouts const&, DB::CompressionMethod, unsigned long, std::vector> const&, std::vector, std::allocator>> const&, bool, bool)::$_0, bool ()>>(std::__function::__policy_storage const*) @ 0x0000000038cacec8 17. ./build_docker/./src/Storages/StorageURL.cpp:422: DB::StorageURLSource::generate() @ 0x0000000038c81b6a 18. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae71153 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 2025.10.23 23:40:25.014912 [ 18545 ] {7dfc4a25-67a4-40db-9a40-86c441db4b4c} TCPHandler: Code: 1000. DB::Exception: Timeout: connect timed out: 128.0.0.1:8123. (POCO_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, String const&, int) @ 0x00000000403edbad 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:0: Poco::TimeoutException::TimeoutException(String const&, String const&, int) @ 0x00000000403f634e 2. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:145: Poco::Net::SocketImpl::connect(Poco::Net::SocketAddress const&, Poco::Timespan const&) @ 0x0000000040619968 3. ./build_docker/./base/poco/Net/src/StreamSocket.cpp:85: Poco::Net::StreamSocket::connect(Poco::Net::SocketAddress const&, Poco::Timespan const&) @ 0x00000000406256ce 4. ./base/poco/Net/include/Poco/Net/Socket.h:422: Poco::Net::HTTPSession::connect(Poco::Net::SocketAddress const&) @ 0x00000000405b79a8 5. ./build_docker/./base/poco/Net/src/HTTPClientSession.cpp:459: Poco::Net::HTTPClientSession::reconnect() @ 0x00000000405759fe 6. ./build_docker/./src/Common/HTTPConnectionPool.cpp:0: DB::EndpointConnectionPool::prepareNewConnection(DB::ConnectionTimeouts const&) @ 0x0000000020747707 7. ./build_docker/./src/Common/HTTPConnectionPool.cpp:0: DB::EndpointConnectionPool::getConnection(DB::ConnectionTimeouts const&) @ 0x00000000207441de 8. ./build_docker/./src/IO/HTTPCommon.cpp:0: DB::makeHTTPSession(DB::HTTPConnectionGroupType, Poco::URI const&, DB::ConnectionTimeouts const&, DB::ProxyConfiguration const&) @ 0x00000000209793f4 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:265: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb28e3 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 11. ./src/IO/ReadWriteBufferFromHTTP.h:52: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbbed 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000020bad484 14. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:755: DB::ReadWriteBufferFromHTTP::getFileInfo() @ 0x0000000020bacade 15. ./contrib/llvm-project/libcxx/include/optional:344: DB::ReadWriteBufferFromHTTP::tryGetLastModificationTime() @ 0x0000000020bbb76b 16. ./build_docker/./src/Storages/StorageURL.cpp:0: bool std::__function::__policy_invoker::__call_impl> ()>>, String const&, std::function>&)>, String const&, std::optional const&, String, std::shared_ptr const&, unsigned long, DB::ConnectionTimeouts const&, DB::CompressionMethod, unsigned long, std::vector> const&, std::vector, std::allocator>> const&, bool, bool)::$_0, bool ()>>(std::__function::__policy_storage const*) @ 0x0000000038cacec8 17. ./build_docker/./src/Storages/StorageURL.cpp:422: DB::StorageURLSource::generate() @ 0x0000000038c81b6a 18. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae71153 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 2025.10.23 23:40:25.118182 [ 3245 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:25.294979 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:25.406621 [ 3524 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:25.785149 [ 18545 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:26.018239 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:26.119259 [ 3418 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:26.332351 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:26.407469 [ 3168 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:26.828450 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:27.071985 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:27.120220 [ 3207 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:27.408960 [ 3517 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:27.421392 [ 3657 ] {eca3dc2f-d725-4477-8dd8-6130f79f34c3::202510_1_15_3_18} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=15, jobs=15). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:27.422381 [ 3657 ] {eca3dc2f-d725-4477-8dd8-6130f79f34c3::202510_1_15_3_18} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=15, jobs=15). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:27.453014 [ 9453 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:27.800518 [ 7652 ] {78cc3d7e-caeb-4bcc-81ef-7a8312c55252} executeQuery: Poco::Exception. Code: 1000, e.code() = 0, Timeout: connect timed out: 128.0.0.1:8123 (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:49582) (comment: 02044_url_glob_parallel_connection_refused.sh) (in query: SELECT * FROM url('http://128.0.0.{1..10}:8123/?query=SELECT+sleep(1)', TSV, 'x UInt8')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, String const&, int) @ 0x00000000403edbad 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:0: Poco::TimeoutException::TimeoutException(String const&, String const&, int) @ 0x00000000403f634e 2. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:145: Poco::Net::SocketImpl::connect(Poco::Net::SocketAddress const&, Poco::Timespan const&) @ 0x0000000040619968 3. ./build_docker/./base/poco/Net/src/StreamSocket.cpp:85: Poco::Net::StreamSocket::connect(Poco::Net::SocketAddress const&, Poco::Timespan const&) @ 0x00000000406256ce 4. ./base/poco/Net/include/Poco/Net/Socket.h:422: Poco::Net::HTTPSession::connect(Poco::Net::SocketAddress const&) @ 0x00000000405b79a8 5. ./build_docker/./base/poco/Net/src/HTTPClientSession.cpp:459: Poco::Net::HTTPClientSession::reconnect() @ 0x00000000405759fe 6. ./build_docker/./src/Common/HTTPConnectionPool.cpp:0: DB::EndpointConnectionPool::prepareNewConnection(DB::ConnectionTimeouts const&) @ 0x0000000020747707 7. ./build_docker/./src/Common/HTTPConnectionPool.cpp:0: DB::EndpointConnectionPool::getConnection(DB::ConnectionTimeouts const&) @ 0x00000000207441de 8. ./build_docker/./src/IO/HTTPCommon.cpp:0: DB::makeHTTPSession(DB::HTTPConnectionGroupType, Poco::URI const&, DB::ConnectionTimeouts const&, DB::ProxyConfiguration const&) @ 0x00000000209793f4 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:265: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb28e3 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 11. ./src/IO/ReadWriteBufferFromHTTP.h:52: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbbed 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000020bad484 14. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:755: DB::ReadWriteBufferFromHTTP::getFileInfo() @ 0x0000000020bacade 15. ./contrib/llvm-project/libcxx/include/optional:344: DB::ReadWriteBufferFromHTTP::tryGetLastModificationTime() @ 0x0000000020bbb76b 16. ./build_docker/./src/Storages/StorageURL.cpp:0: bool std::__function::__policy_invoker::__call_impl> ()>>, String const&, std::function>&)>, String const&, std::optional const&, String, std::shared_ptr const&, unsigned long, DB::ConnectionTimeouts const&, DB::CompressionMethod, unsigned long, std::vector> const&, std::vector, std::allocator>> const&, bool, bool)::$_0, bool ()>>(std::__function::__policy_storage const*) @ 0x0000000038cacec8 17. ./build_docker/./src/Storages/StorageURL.cpp:422: DB::StorageURLSource::generate() @ 0x0000000038c81b6a 18. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae71153 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 2025.10.23 23:40:27.802857 [ 7652 ] {78cc3d7e-caeb-4bcc-81ef-7a8312c55252} TCPHandler: Code: 1000. DB::Exception: Timeout: connect timed out: 128.0.0.1:8123. (POCO_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, String const&, int) @ 0x00000000403edbad 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:0: Poco::TimeoutException::TimeoutException(String const&, String const&, int) @ 0x00000000403f634e 2. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:145: Poco::Net::SocketImpl::connect(Poco::Net::SocketAddress const&, Poco::Timespan const&) @ 0x0000000040619968 3. ./build_docker/./base/poco/Net/src/StreamSocket.cpp:85: Poco::Net::StreamSocket::connect(Poco::Net::SocketAddress const&, Poco::Timespan const&) @ 0x00000000406256ce 4. ./base/poco/Net/include/Poco/Net/Socket.h:422: Poco::Net::HTTPSession::connect(Poco::Net::SocketAddress const&) @ 0x00000000405b79a8 5. ./build_docker/./base/poco/Net/src/HTTPClientSession.cpp:459: Poco::Net::HTTPClientSession::reconnect() @ 0x00000000405759fe 6. ./build_docker/./src/Common/HTTPConnectionPool.cpp:0: DB::EndpointConnectionPool::prepareNewConnection(DB::ConnectionTimeouts const&) @ 0x0000000020747707 7. ./build_docker/./src/Common/HTTPConnectionPool.cpp:0: DB::EndpointConnectionPool::getConnection(DB::ConnectionTimeouts const&) @ 0x00000000207441de 8. ./build_docker/./src/IO/HTTPCommon.cpp:0: DB::makeHTTPSession(DB::HTTPConnectionGroupType, Poco::URI const&, DB::ConnectionTimeouts const&, DB::ProxyConfiguration const&) @ 0x00000000209793f4 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:265: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bb28e3 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bb2f55 11. ./src/IO/ReadWriteBufferFromHTTP.h:52: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bbbbed 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020bad97f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000020bad484 14. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:755: DB::ReadWriteBufferFromHTTP::getFileInfo() @ 0x0000000020bacade 15. ./contrib/llvm-project/libcxx/include/optional:344: DB::ReadWriteBufferFromHTTP::tryGetLastModificationTime() @ 0x0000000020bbb76b 16. ./build_docker/./src/Storages/StorageURL.cpp:0: bool std::__function::__policy_invoker::__call_impl> ()>>, String const&, std::function>&)>, String const&, std::optional const&, String, std::shared_ptr const&, unsigned long, DB::ConnectionTimeouts const&, DB::CompressionMethod, unsigned long, std::vector> const&, std::vector, std::allocator>> const&, bool, bool)::$_0, bool ()>>(std::__function::__policy_storage const*) @ 0x0000000038cacec8 17. ./build_docker/./src/Storages/StorageURL.cpp:422: DB::StorageURLSource::generate() @ 0x0000000038c81b6a 18. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae71153 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 2025.10.23 23:40:27.946597 [ 3346 ] {} test_3.table1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.10.23 23:40:27.946871 [ 3330 ] {} test_3.`02691_drop_column_replicated` (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.10.23 23:40:27.948251 [ 3557 ] {} test_3.rmt (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.10.23 23:40:27.948583 [ 3173 ] {} test_15.r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.10.23 23:40:27.950684 [ 3142 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02725_start_stop_fetches_test_15/r/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:27.950986 [ 3212 ] {} test_3.rmt (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /test/02253/02253_empty_part_checksums_test_3/rmt/blocks. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x0000000030538e6c 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe8649 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000003cbe7761 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x000000003a061e9e 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x000000003a04fe19 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a041419 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:50: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a03dd98 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003a06697f 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:27.951364 [ 3462 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000003cc8de51 3. ./src/Common/ZooKeeper/IKeeper.h:509: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003cd16a3e 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003cd2369f 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe6e6d 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe5f26 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe84e7 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe81ea 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000003a10064e 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000003889f11d 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f9f 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:27.962790 [ 3212 ] {} test_3.rmt (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000003cc8de51 3. ./src/Common/ZooKeeper/IKeeper.h:509: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003cd16a3e 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000003cd20792 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryExistsNoThrow(String const&, std::function) @ 0x000000003cbf3581 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003cbf26a1 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000003cbf3a70 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003cbea871 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000003a0439c9 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a04133c 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:50: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a03dd98 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003a06697f 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 15. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:28.009690 [ 9453 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:28.120905 [ 3290 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:28.121069 [ 4675 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:28.409824 [ 3232 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:28.568854 [ 4675 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:28.851077 [ 4841 ] {3d468999-a993-449d-b7c7-7ef8aaca26d5} executeQuery: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_18.txt' with part '202510_1_15_3' reason: 'Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=15, jobs=15). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.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.10542.altinitytest (altinity build)) (from [::1]:49678) (comment: 02834_remote_session_log.sh) (in query: DELETE FROM system.session_log WHERE user = '02834_USER_21721'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&) @ 0x0000000039c1c97f 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000039c1c6e5 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003a2fe259 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003a3016f5 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034866f33 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003485e550 9. ./src/Interpreters/InterpreterAlterQuery.h:18: DB::InterpreterDeleteQuery::execute()::$_0::operator()() const @ 0x0000000035a855e3 10. ./build_docker/./src/Interpreters/InterpreterDeleteQuery.cpp:118: DB::InterpreterDeleteQuery::execute() @ 0x0000000035a7f3c6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:40:28.853607 [ 4841 ] {3d468999-a993-449d-b7c7-7ef8aaca26d5} TCPHandler: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_18.txt' with part '202510_1_15_3' reason: 'Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=15, jobs=15). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&) @ 0x0000000039c1c97f 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000039c1c6e5 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003a2fe259 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003a3016f5 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034866f33 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003485e550 9. ./src/Interpreters/InterpreterAlterQuery.h:18: DB::InterpreterDeleteQuery::execute()::$_0::operator()() const @ 0x0000000035a855e3 10. ./build_docker/./src/Interpreters/InterpreterDeleteQuery.cpp:118: DB::InterpreterDeleteQuery::execute() @ 0x0000000035a7f3c6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:40:29.102281 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:29.121639 [ 3093 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:29.283315 [ 4675 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:29.410961 [ 3072 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:29.643527 [ 4675 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:30.122464 [ 3207 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:30.211563 [ 4675 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:30.357090 [ 4675 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:30.412174 [ 3237 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:30.745655 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:31.123269 [ 3194 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:31.304165 [ 4675 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:31.413101 [ 3217 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:31.441979 [ 4675 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:31.791680 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:32.124159 [ 3473 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:32.249036 [ 9557 ] {af0959e1-ac61-4ac6-95dd-6769355c0d13} executeQuery: Code: 43. DB::Exception: Cannot reinterpret String as FixedString because it is not fixed size and contiguous in memory: In scope SELECT reinterpret('123', 'FixedString(1)'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:49648) (comment: 01676_reinterpret_as.sql) (in query: SELECT reinterpret('123', 'FixedString(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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. DB::(anonymous namespace)::FunctionReinterpret::getReturnTypeImpl(std::vector> const&) const @ 0x000000001bd2600d 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083d29bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60aa37 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b609cba 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60b9ac 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334af94d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 31. ? @ 0x00007f100c857ac3 2025.10.23 23:40:32.250564 [ 9557 ] {af0959e1-ac61-4ac6-95dd-6769355c0d13} TCPHandler: Code: 43. DB::Exception: Cannot reinterpret String as FixedString because it is not fixed size and contiguous in memory: In scope SELECT reinterpret('123', 'FixedString(1)'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. DB::(anonymous namespace)::FunctionReinterpret::getReturnTypeImpl(std::vector> const&) const @ 0x000000001bd2600d 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083d29bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60aa37 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b609cba 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60b9ac 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334af94d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 31. ? @ 0x00007f100c857ac3 2025.10.23 23:40:32.351003 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:32.413917 [ 3448 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:32.541121 [ 18542 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:32.866201 [ 4675 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:33.085685 [ 7565 ] {089aba24-c2ab-4a6e-bb7c-5eca69f6a9c3} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:49870) (comment: 01274_alter_rename_column_distributed.sql) (in query: CREATE TABLE visits (`StartDate` Date, `Name` String) ENGINE = MergeTree ORDER BY StartDate SETTINGS index_granularity = 307, min_bytes_for_wide_part = 199230001, 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 = 49103802, compact_parts_max_granules_to_buffer = 37, compact_parts_merge_max_bytes_to_prefetch_part = 5528067, merge_max_block_size = 6856, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 417745, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 6083318, concurrent_part_removal_threshold = 36, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 29572, primary_key_compress_block_size = 43684), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x0000000039709f85 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>) @ 0x000000003a2e5f4a 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a2e404f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2d3063 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7b27a 12. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x0000000038308626 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348e414c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:40:33.125034 [ 3107 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:33.145883 [ 7565 ] {089aba24-c2ab-4a6e-bb7c-5eca69f6a9c3} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x0000000039709f85 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>) @ 0x000000003a2e5f4a 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a2e404f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2d3063 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7b27a 12. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x0000000038308626 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348e414c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:40:33.414696 [ 3509 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:33.420010 [ 4752 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:33.596308 [ 4752 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:33.933061 [ 4752 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:34.125766 [ 3324 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:34.416114 [ 3317 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:34.478749 [ 4752 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:34.534137 [ 9453 ] {bde7ccb7-c7d8-46a8-b5ed-3597a060181b} 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.10542.altinitytest (altinity build)) (from [::1]:49718) (comment: 02997_fix_datetime64_scale_conversion.sql) (in query: SELECT * FROM test_0 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 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) @ 0x0000000039c89948 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000003999bfb7 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 @ 0x00000000399942f0 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039d45fb0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003bfd663a 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c083c53 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003bfe2b53 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d3c440 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf89b85 18. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 19. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 25. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 27. ? @ 0x00007f100c857ac3 28. ? @ 0x00007f100c8e9850 2025.10.23 23:40:34.538403 [ 9453 ] {bde7ccb7-c7d8-46a8-b5ed-3597a060181b} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 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) @ 0x0000000039c89948 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000003999bfb7 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 @ 0x00000000399942f0 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039d45fb0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003bfd663a 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c083c53 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003bfe2b53 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d3c440 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf89b85 18. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 19. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 25. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 27. ? @ 0x00007f100c857ac3 28. ? @ 0x00007f100c8e9850 2025.10.23 23:40:34.770985 [ 4752 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:34.971976 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:35.126469 [ 3115 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:35.417028 [ 3485 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:35.502369 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:35.904706 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:36.012616 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:36.127465 [ 3305 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:36.417895 [ 3386 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:36.554897 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:36.977756 [ 4752 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:37.070482 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:37.128462 [ 3223 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:37.418681 [ 3227 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:37.630540 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:37.717887 [ 7652 ] {434c390a-4422-4af6-b05a-359a7bea16d9} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, jobs=15). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:35470) (comment: 02046_low_cardinality_parallel_group_by.sh) (in query: SELECT count() FROM low_card_buffer_test GROUP BY test_text 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6377 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 2025.10.23 23:40:37.722636 [ 7652 ] {434c390a-4422-4af6-b05a-359a7bea16d9} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6377 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 2025.10.23 23:40:37.864983 [ 7565 ] {2c28cc31-ddc8-4133-8c1c-1cde71f93128} 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.10542.altinitytest (altinity build)) (from [::1]:35436) (comment: 02046_low_cardinality_parallel_group_by.sh) (in query: SELECT count() FROM low_card_buffer_test GROUP BY test_text 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6377 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 2025.10.23 23:40:37.869021 [ 7565 ] {2c28cc31-ddc8-4133-8c1c-1cde71f93128} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6377 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 2025.10.23 23:40:38.031572 [ 2903 ] {726e31de-1291-44f9-98e6-c3dbfbd49540} executeQuery: Code: 131. DB::Exception: The string size is too big for function editDistance, should be at most 65536: while executing 'FUNCTION editDistance(randomString(_CAST(131072._Float64, 'Float64'_String)) :: 3, 'abc'_String :: 2) -> editDistance(randomString(_CAST(131072._Float64, 'Float64'_String)), 'abc'_String) UInt64 : 1'. (TOO_LARGE_STRING_SIZE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:49902) (comment: 02884_string_distance_function.sql) (in query: SELECT editDistance(randomString(power(2, 17)), 'abc');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000b46526a 4. DB::ByteEditDistanceImpl::process(char const*, unsigned long, char const*, unsigned long) @ 0x000000000b464f9a 5. DB::FunctionsStringSimilarity>, DB::NameEditDistance>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b46238e 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d57db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffeaa 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a24ade 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b82c484 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acdc84 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae66ecb 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 21. ? @ 0x00007f100c857ac3 22. ? @ 0x00007f100c8e9850 2025.10.23 23:40:38.032947 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:38.033218 [ 2903 ] {726e31de-1291-44f9-98e6-c3dbfbd49540} TCPHandler: Code: 131. DB::Exception: The string size is too big for function editDistance, should be at most 65536: while executing 'FUNCTION editDistance(randomString(_CAST(131072._Float64, 'Float64'_String)) :: 3, 'abc'_String :: 2) -> editDistance(randomString(_CAST(131072._Float64, 'Float64'_String)), 'abc'_String) UInt64 : 1'. (TOO_LARGE_STRING_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000b46526a 4. DB::ByteEditDistanceImpl::process(char const*, unsigned long, char const*, unsigned long) @ 0x000000000b464f9a 5. DB::FunctionsStringSimilarity>, DB::NameEditDistance>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b46238e 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d57db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffeaa 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a24ade 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b82c484 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acdc84 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae66ecb 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 21. ? @ 0x00007f100c857ac3 22. ? @ 0x00007f100c8e9850 2025.10.23 23:40:38.115823 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:38.129036 [ 3093 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:38.419475 [ 3544 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:38.679538 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:39.061261 [ 18540 ] {233458f4-1638-422c-8dff-39094769b035} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=749). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:35424) (comment: 02046_low_cardinality_parallel_group_by.sh) (in query: INSERT INTO low_card_buffer_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003ae9ffe4 7. ./build_docker/./src/Server/TCPHandler.cpp:621: DB::TCPHandler::runImpl() @ 0x000000003abd95ce 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 2025.10.23 23:40:39.063401 [ 18540 ] {233458f4-1638-422c-8dff-39094769b035} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=749). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003ae9ffe4 7. ./build_docker/./src/Server/TCPHandler.cpp:621: DB::TCPHandler::runImpl() @ 0x000000003abd95ce 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 2025.10.23 23:40:39.113222 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:39.129831 [ 3478 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:39.180666 [ 4752 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:39.374669 [ 2903 ] {58075c97-b2bb-405d-86b5-0af5d9620d89} executeQuery: Code: 131. DB::Exception: The string size is too big for function damerauLevenshteinDistance, should be at most 65536: while executing 'FUNCTION damerauLevenshteinDistance(randomString(_CAST(131072._Float64, 'Float64'_String)) :: 3, 'abc'_String :: 2) -> damerauLevenshteinDistance(randomString(_CAST(131072._Float64, 'Float64'_String)), 'abc'_String) UInt64 : 1'. (TOO_LARGE_STRING_SIZE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:49902) (comment: 02884_string_distance_function.sql) (in query: SELECT damerauLevenshteinDistance(randomString(power(2, 17)), 'abc');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000b46526a 4. DB::ByteDamerauLevenshteinDistanceImpl::process(char const*, unsigned long, char const*, unsigned long) @ 0x000000000b46f996 5. DB::FunctionsStringSimilarity, DB::NameDamerauLevenshteinDistance>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b46ce8e 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d57db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffeaa 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a24ade 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b82c484 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acdc84 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae66ecb 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 21. ? @ 0x00007f100c857ac3 22. ? @ 0x00007f100c8e9850 2025.10.23 23:40:39.376258 [ 2903 ] {58075c97-b2bb-405d-86b5-0af5d9620d89} TCPHandler: Code: 131. DB::Exception: The string size is too big for function damerauLevenshteinDistance, should be at most 65536: while executing 'FUNCTION damerauLevenshteinDistance(randomString(_CAST(131072._Float64, 'Float64'_String)) :: 3, 'abc'_String :: 2) -> damerauLevenshteinDistance(randomString(_CAST(131072._Float64, 'Float64'_String)), 'abc'_String) UInt64 : 1'. (TOO_LARGE_STRING_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000b46526a 4. DB::ByteDamerauLevenshteinDistanceImpl::process(char const*, unsigned long, char const*, unsigned long) @ 0x000000000b46f996 5. DB::FunctionsStringSimilarity, DB::NameDamerauLevenshteinDistance>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b46ce8e 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d57db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffeaa 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a24ade 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b82c484 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acdc84 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae66ecb 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 21. ? @ 0x00007f100c857ac3 22. ? @ 0x00007f100c8e9850 2025.10.23 23:40:39.420193 [ 3423 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:39.740877 [ 18540 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:39.832091 [ 3933 ] {e06ac522-bcaa-471b-8d0f-788365d1c4f4} 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.10542.altinitytest (altinity build)) (from [::1]:35500) (comment: 02834_remote_session_log.sh) (in query: SELECT count(*) FROM system.session_log WHERE user = '02834_USER_21721' and client_address = toIPv6('::')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 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) @ 0x0000000039c89948 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000003999bfb7 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 @ 0x00000000399942f0 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039d46d05 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003bfd663a 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c083c53 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003bfe2b53 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d3c440 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf89b85 18. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 19. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 23. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 24. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 26. ? @ 0x00007f100c857ac3 27. ? @ 0x00007f100c8e9850 2025.10.23 23:40:39.836147 [ 3933 ] {e06ac522-bcaa-471b-8d0f-788365d1c4f4} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 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) @ 0x0000000039c89948 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000003999bfb7 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 @ 0x00000000399942f0 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039d46d05 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003bfd663a 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c083c53 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003bfe2b53 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d3c440 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf89b85 18. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 19. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 23. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 24. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 26. ? @ 0x00007f100c857ac3 27. ? @ 0x00007f100c8e9850 2025.10.23 23:40:40.130656 [ 3257 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:40.136397 [ 18540 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:40.260233 [ 18540 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:40.420962 [ 3431 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:40.791885 [ 4745 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:41.131364 [ 3302 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:41.253014 [ 18540 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:41.321280 [ 4745 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:41.421624 [ 3251 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:41.457161 [ 2903 ] {e99c2d6f-b32d-4201-8091-6891ff81cade} executeQuery: Code: 131. DB::Exception: The string size is too big for function jaroSimilarity, should be at most 65536: while executing 'FUNCTION jaroSimilarity(randomString(_CAST(131072._Float64, 'Float64'_String)) :: 3, 'abc'_String :: 2) -> jaroSimilarity(randomString(_CAST(131072._Float64, 'Float64'_String)), 'abc'_String) Float64 : 1'. (TOO_LARGE_STRING_SIZE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:49902) (comment: 02884_string_distance_function.sql) (in query: SELECT jaroSimilarity(randomString(power(2, 17)), 'abc');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000b46526a 4. DB::ByteJaroSimilarityImpl::process(char const*, unsigned long, char const*, unsigned long) @ 0x000000000b47e321 5. DB::FunctionsStringSimilarity, DB::NameJaroSimilarity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b47bf2e 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d57db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffeaa 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a24ade 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b82c484 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acdc84 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae66ecb 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 21. ? @ 0x00007f100c857ac3 22. ? @ 0x00007f100c8e9850 2025.10.23 23:40:41.459614 [ 2903 ] {e99c2d6f-b32d-4201-8091-6891ff81cade} TCPHandler: Code: 131. DB::Exception: The string size is too big for function jaroSimilarity, should be at most 65536: while executing 'FUNCTION jaroSimilarity(randomString(_CAST(131072._Float64, 'Float64'_String)) :: 3, 'abc'_String :: 2) -> jaroSimilarity(randomString(_CAST(131072._Float64, 'Float64'_String)), 'abc'_String) Float64 : 1'. (TOO_LARGE_STRING_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000b46526a 4. DB::ByteJaroSimilarityImpl::process(char const*, unsigned long, char const*, unsigned long) @ 0x000000000b47e321 5. DB::FunctionsStringSimilarity, DB::NameJaroSimilarity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b47bf2e 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d57db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffeaa 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a24ade 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b82c484 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acdc84 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae66ecb 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 21. ? @ 0x00007f100c857ac3 22. ? @ 0x00007f100c8e9850 2025.10.23 23:40:41.837414 [ 18540 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:42.153083 [ 3204 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:42.285649 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:42.371411 [ 18540 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:42.422315 [ 3419 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:42.884320 [ 4745 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:43.154031 [ 3255 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:43.300399 [ 4745 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:43.423535 [ 3335 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:43.491194 [ 4745 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:44.018899 [ 18540 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:44.035063 [ 2903 ] {97683393-52e4-4e31-9f02-6d752f4a8069} executeQuery: Code: 131. DB::Exception: The string size is too big for function jaroWinklerSimilarity, should be at most 65536: while executing 'FUNCTION jaroWinklerSimilarity(randomString(_CAST(131072._Float64, 'Float64'_String)) :: 3, 'abc'_String :: 2) -> jaroWinklerSimilarity(randomString(_CAST(131072._Float64, 'Float64'_String)), 'abc'_String) Float64 : 1'. (TOO_LARGE_STRING_SIZE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:49902) (comment: 02884_string_distance_function.sql) (in query: SELECT jaroWinklerSimilarity(randomString(power(2, 17)), 'abc');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000b46526a 4. DB::ByteJaroWinklerSimilarityImpl::process(char const*, unsigned long, char const*, unsigned long) @ 0x000000000b481d96 5. DB::FunctionsStringSimilarity, DB::NameJaroWinklerSimilarity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b47ff6e 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d57db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffeaa 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a24ade 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b82c484 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acdc84 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae66ecb 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 21. ? @ 0x00007f100c857ac3 22. ? @ 0x00007f100c8e9850 2025.10.23 23:40:44.038033 [ 2903 ] {97683393-52e4-4e31-9f02-6d752f4a8069} TCPHandler: Code: 131. DB::Exception: The string size is too big for function jaroWinklerSimilarity, should be at most 65536: while executing 'FUNCTION jaroWinklerSimilarity(randomString(_CAST(131072._Float64, 'Float64'_String)) :: 3, 'abc'_String :: 2) -> jaroWinklerSimilarity(randomString(_CAST(131072._Float64, 'Float64'_String)), 'abc'_String) Float64 : 1'. (TOO_LARGE_STRING_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000b46526a 4. DB::ByteJaroWinklerSimilarityImpl::process(char const*, unsigned long, char const*, unsigned long) @ 0x000000000b481d96 5. DB::FunctionsStringSimilarity, DB::NameJaroWinklerSimilarity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b47ff6e 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d57db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffeaa 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a24ade 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b82c484 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acdc84 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae66ecb 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 21. ? @ 0x00007f100c857ac3 22. ? @ 0x00007f100c8e9850 2025.10.23 23:40:44.154809 [ 3128 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:44.378702 [ 4745 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:44.424672 [ 3529 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:44.561517 [ 4745 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:45.155542 [ 3235 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:45.183624 [ 18540 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:45.425555 [ 3321 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:45.486681 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:45.643797 [ 4752 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:45.997841 [ 2903 ] {d1bc49d6-6279-4b3e-933e-3bc769f20464} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, jobs=0): (while reading column s1): (while reading from part /var/lib/clickhouse/store/f65/f65024ed-dbec-4f43-9340-051ceb4942a9/all_1_1_0/ in table test_c01oqrhq.t (f65024ed-dbec-4f43-9340-051ceb4942a9) located on disk default of type local, from mark 0 with max_rows_to_read = 10): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:49902) (comment: 02884_string_distance_function.sql) (in query: SELECT 'byteHammingDistance', s1, s2, byteHammingDistance(s1, s2) FROM t 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000003075641a 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030755c60 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000307521d1 9. ./src/IO/AsynchronousReader.h:48: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000003073084e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000003073196f 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:163: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x00000000320e5233 13. ./build_docker/./src/Compression/CachedCompressedReadBuffer.cpp:52: DB::CachedCompressedReadBuffer::nextImpl() @ 0x0000000039cf9be8 14. ./build_docker/./src/Compression/CachedCompressedReadBuffer.cpp:0: non-virtual thunk to DB::CachedCompressedReadBuffer::nextImpl() @ 0x0000000039cfb48d 15. DB::ReadBuffer::next() @ 0x00000000095b468f 16. ./src/IO/ReadBuffer.h:106: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000003283c39d 17. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:0: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000032838fb2 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 @ 0x0000000032642210 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:216: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039c8e35d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:0: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ce6eb1 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039cb3032 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039cd6816 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000039ccef53 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000039d4a566 25. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000003bfe52b4 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:206: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d3c6b0 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf89b85 28. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 29. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 2025.10.23 23:40:46.000429 [ 2903 ] {d1bc49d6-6279-4b3e-933e-3bc769f20464} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, jobs=0): (while reading column s1): (while reading from part /var/lib/clickhouse/store/f65/f65024ed-dbec-4f43-9340-051ceb4942a9/all_1_1_0/ in table test_c01oqrhq.t (f65024ed-dbec-4f43-9340-051ceb4942a9) located on disk default of type local, from mark 0 with max_rows_to_read = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000003075641a 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030755c60 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000307521d1 9. ./src/IO/AsynchronousReader.h:48: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000003073084e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000003073196f 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:163: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x00000000320e5233 13. ./build_docker/./src/Compression/CachedCompressedReadBuffer.cpp:52: DB::CachedCompressedReadBuffer::nextImpl() @ 0x0000000039cf9be8 14. ./build_docker/./src/Compression/CachedCompressedReadBuffer.cpp:0: non-virtual thunk to DB::CachedCompressedReadBuffer::nextImpl() @ 0x0000000039cfb48d 15. DB::ReadBuffer::next() @ 0x00000000095b468f 16. ./src/IO/ReadBuffer.h:106: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000003283c39d 17. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:0: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000032838fb2 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 @ 0x0000000032642210 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:216: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039c8e35d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:0: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ce6eb1 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039cb3032 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039cd6816 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000039ccef53 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000039d4a566 25. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000003bfe52b4 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:206: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d3c6b0 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf89b85 28. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 29. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 2025.10.23 23:40:46.156204 [ 3339 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:46.227837 [ 18545 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:46.426305 [ 3260 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:46.526535 [ 18545 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:46.618746 [ 4752 ] {499015af-38fc-4267-ae7a-c73d45c6e77a} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=749). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:41830) (comment: 00647_histogram.sql) (in query: WITH arrayJoin(histogram(3)(sin(number))) AS res select round(res.1, 2), round(res.2, 2), round(res.3, 2) from (select * from system.numbers limit 10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:40:46.624125 [ 4752 ] {499015af-38fc-4267-ae7a-c73d45c6e77a} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=749). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:40:46.736671 [ 4752 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:47.157213 [ 3283 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:47.314609 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:47.427237 [ 3519 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:47.598757 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:47.795063 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:48.003483 [ 4694 ] {dfad7c9e-47d7-4942-bf4a-791ef6ec0a6e} executeQuery: Code: 57. DB::Exception: Table test_3.test already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:41926) (comment: 03033_analyzer_merge_engine_filter_push_down.sql) (in query: CREATE TABLE test (`x` LowCardinality(Nullable(UInt32)), `y` String) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 37079, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.6262325048446655, replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 331947333, compact_parts_max_bytes_to_buffer = 93230838, compact_parts_max_granules_to_buffer = 31, compact_parts_merge_max_bytes_to_prefetch_part = 32699296, merge_max_block_size = 6439, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 951613, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 21130859, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 90734, primary_key_compress_block_size = 57983), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:40:48.006159 [ 4694 ] {dfad7c9e-47d7-4942-bf4a-791ef6ec0a6e} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:40:48.158154 [ 3079 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:48.382469 [ 4752 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:48.428189 [ 3210 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:48.634512 [ 4752 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:48.855053 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:49.158803 [ 3499 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:49.181320 [ 18545 ] {1a8f2ec1-cdfc-44b7-afd9-280e6bf21e41} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:41962) (comment: 03035_argMinMax_numeric_non_extreme_bug.sql) (in query: SELECT max(time), max(toNullable(time)), min(time), min(toNullable(time)), argMax(value, time), argMax(value, toNullable(time)), argMin(value, time), argMin(value, toNullable(time)), argMinIf(value, toNullable(time), time != '2021-01-01 00:00:00.000'), argMaxIf(value, toNullable(time), time != '2021-01-01 00:00:59.000'), FROM test WHERE (time >= fromUnixTimestamp64Milli(1609459200000, 'UTC')) AND (time < fromUnixTimestamp64Milli(1609459260000, 'UTC')) 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:40:49.271117 [ 18545 ] {1a8f2ec1-cdfc-44b7-afd9-280e6bf21e41} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:40:49.429223 [ 3089 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:49.454454 [ 7652 ] {5dc3ec64-b785-4e76-9b5a-77539037f8c0} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37660) (comment: 03035_argMinMax_numeric_non_extreme_bug.sql) (in query: DROP DATABASE IF EXISTS test_j5apsgnl ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:40:49.457981 [ 7652 ] {5dc3ec64-b785-4e76-9b5a-77539037f8c0} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:49.466556 [ 18545 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:49.655444 [ 18545 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:49.900764 [ 18545 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:50.159544 [ 3479 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:50.237703 [ 3655 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {d60c8165-1f8c-4cd1-8084-8b8c63363ea3::202510_60_82_4}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 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) @ 0x0000000039c89948 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000003999bfb7 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 @ 0x00000000399942f0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000039d15c04 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&) @ 0x0000000039d20399 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) @ 0x0000000039d1c606 15. ./contrib/llvm-project/libcxx/include/optional:260: DB::MergeTask::VerticalMergeStage::createPipeForReadingOneColumn(String const&) const @ 0x000000003963fa21 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::prepareVerticalMergeForOneColumn() const @ 0x0000000039641691 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::executeVerticalMergeForAllColumns() const @ 0x00000000396522a9 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1004: DB::MergeTask::VerticalMergeStage::execute() @ 0x0000000039651c40 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x00000000396504a0 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3c455d 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:50.430269 [ 3284 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:50.535128 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:50.700190 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:50.718271 [ 4752 ] {a77be367-bef8-47d7-9021-1f8241716e2a} executeQuery: Code: 47. DB::Exception: JOIN ALL RIGHT JOIN ... USING (s) using identifier 's' cannot be resolved from left table expression. In scope SELECT count() FROM (SELECT [1], count(1)) AS t1 ALL RIGHT JOIN (SELECT number AS s FROM numbers(2)) AS t2 USING (s). (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:41952) (comment: 01010_pm_join_all_join_bug.sql) (in query: SELECT count() FROM ( SELECT [1], count(1) ) AS t1 ALL RIGHT JOIN ( SELECT number AS s FROM numbers(2) ) AS t2 USING (s);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&, String&&) @ 0x000000003350293f 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5108: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334f9880 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334edd53 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436960 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:40:50.720074 [ 4752 ] {a77be367-bef8-47d7-9021-1f8241716e2a} TCPHandler: Code: 47. DB::Exception: JOIN ALL RIGHT JOIN ... USING (s) using identifier 's' cannot be resolved from left table expression. In scope SELECT count() FROM (SELECT [1], count(1)) AS t1 ALL RIGHT JOIN (SELECT number AS s FROM numbers(2)) AS t2 USING (s). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&, String&&) @ 0x000000003350293f 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5108: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334f9880 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334edd53 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436960 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:40:50.953787 [ 4752 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:51.160362 [ 3187 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:51.431082 [ 3193 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:51.602223 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:51.755510 [ 3658 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {d60c8165-1f8c-4cd1-8084-8b8c63363ea3::202510_60_82_4}: 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 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) @ 0x0000000039c89948 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000003999bfb7 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 @ 0x00000000399942f0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000039d15c04 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&) @ 0x0000000039d20399 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) @ 0x0000000039d1c606 15. ./contrib/llvm-project/libcxx/include/optional:260: DB::MergeTask::VerticalMergeStage::createPipeForReadingOneColumn(String const&) const @ 0x000000003963fa21 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::prepareVerticalMergeForOneColumn() const @ 0x0000000039641691 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::executeVerticalMergeForAllColumns() const @ 0x00000000396522a9 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1004: DB::MergeTask::VerticalMergeStage::execute() @ 0x0000000039651c40 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x00000000396504a0 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3c455d 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:51.765177 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:51.996054 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:52.161159 [ 3184 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:52.431933 [ 3215 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:52.647277 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:52.799983 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:53.112680 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:53.162124 [ 3346 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:53.240621 [ 3644 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {d60c8165-1f8c-4cd1-8084-8b8c63363ea3::202510_60_82_4}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 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) @ 0x0000000039c89948 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000003999bfb7 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 @ 0x00000000399942f0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000039d15c04 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&) @ 0x0000000039d20399 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) @ 0x0000000039d1c606 15. ./contrib/llvm-project/libcxx/include/optional:260: DB::MergeTask::VerticalMergeStage::createPipeForReadingOneColumn(String const&) const @ 0x000000003963fa21 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::prepareVerticalMergeForOneColumn() const @ 0x0000000039641691 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::executeVerticalMergeForAllColumns() const @ 0x00000000396522a9 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1004: DB::MergeTask::VerticalMergeStage::execute() @ 0x0000000039651c40 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x00000000396504a0 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3c455d 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:53.432754 [ 3123 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:53.687057 [ 9453 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:53.852540 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:54.163141 [ 3565 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:54.203408 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:54.433754 [ 3311 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:54.778090 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:54.913618 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:55.228702 [ 3387 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:55.379965 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:55.434675 [ 3405 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:55.880438 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:55.943672 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:56.229425 [ 3081 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:56.435514 [ 3324 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:56.457750 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:56.957774 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:56.959733 [ 18542 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:57.230081 [ 3286 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:57.436688 [ 3344 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:57.531167 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:58.001290 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:58.018741 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:58.230912 [ 3133 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:58.437806 [ 3230 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:58.590346 [ 18542 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:59.088549 [ 9453 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:59.088992 [ 4675 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:40:59.231633 [ 3061 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:59.438894 [ 3283 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:59.643991 [ 4675 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:00.196607 [ 18542 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:00.232446 [ 3551 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:00.351039 [ 4675 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:00.440267 [ 3079 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:00.501131 [ 2904 ] {2d799caf-03c2-4d5e-a7de-77d0f694bebb} executeQuery: Code: 80. DB::Exception: It's not initial query. ON CLUSTER is not allowed for Replicated database. (INCORRECT_QUERY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37076) (comment: 02933_replicated_database_forbid_create_as_select.sh) (in query: DROP DATABASE test_11_db), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a555bd 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:222: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003493e6e9 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeDropQuery(DB::ASTDropQuery::Kind, std::shared_ptr, std::shared_ptr, DB::StorageID const&, bool, bool, bool) @ 0x000000003494c9cc 10. ./build_docker/./src/Storages/StorageMaterializedView.cpp:355: DB::StorageMaterializedView::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000038587520 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003493f2d5 12. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:454: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034947b8d 13. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 14. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 15. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:41:00.503647 [ 2904 ] {2d799caf-03c2-4d5e-a7de-77d0f694bebb} TCPHandler: Code: 80. DB::Exception: It's not initial query. ON CLUSTER is not allowed for Replicated database. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a555bd 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:222: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003493e6e9 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeDropQuery(DB::ASTDropQuery::Kind, std::shared_ptr, std::shared_ptr, DB::StorageID const&, bool, bool, bool) @ 0x000000003494c9cc 10. ./build_docker/./src/Storages/StorageMaterializedView.cpp:355: DB::StorageMaterializedView::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000038587520 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003493f2d5 12. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:454: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034947b8d 13. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 14. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 15. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:41:00.721248 [ 18542 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:01.261364 [ 3239 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:01.305272 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:01.412229 [ 18542 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:01.441280 [ 3370 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:01.764652 [ 18542 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:02.262313 [ 3192 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:02.349439 [ 18542 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:02.442042 [ 3257 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:02.460265 [ 18542 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:02.829333 [ 18542 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:03.263273 [ 3550 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:03.281871 [ 4675 ] {75c0a38a-c26a-4099-9612-9253488d98ed} executeQuery: Code: 43. DB::Exception: Second argument of function fuzzBits must be constant float: In scope SELECT fuzzBits(toString('string'), 1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37664) (comment: 01284_fuzz_bits.sql) (in query: SELECT fuzzBits(toString('string'), 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. DB::(anonymous namespace)::FunctionFuzzBits::getReturnTypeImpl(std::vector> const&) const @ 0x000000000fb692e6 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083d29bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60aa37 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b609cba 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60b9ac 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334af94d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 31. ? @ 0x00007f100c857ac3 2025.10.23 23:41:03.283472 [ 4675 ] {75c0a38a-c26a-4099-9612-9253488d98ed} TCPHandler: Code: 43. DB::Exception: Second argument of function fuzzBits must be constant float: In scope SELECT fuzzBits(toString('string'), 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. DB::(anonymous namespace)::FunctionFuzzBits::getReturnTypeImpl(std::vector> const&) const @ 0x000000000fb692e6 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083d29bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60aa37 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b609cba 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60b9ac 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334af94d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 31. ? @ 0x00007f100c857ac3 2025.10.23 23:41:03.415100 [ 18542 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:03.442701 [ 3448 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:03.528013 [ 18542 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:03.895191 [ 18545 ] {7cdcad16-7214-4a66-b48e-a8dfd1f65ea1} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37020) (comment: 02098_with_types_use_header.sh) (in query: DROP DATABASE IF EXISTS test_3kvgwciy ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:41:03.897731 [ 18545 ] {7cdcad16-7214-4a66-b48e-a8dfd1f65ea1} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:03.917086 [ 7565 ] {25ca8377-6b99-4ff3-abb3-b43abd5e2b48} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37024) (comment: 02098_with_types_use_header.sh) (in query: DROP DATABASE IF EXISTS test_3kvgwciy ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:41:03.919360 [ 7565 ] {25ca8377-6b99-4ff3-abb3-b43abd5e2b48} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:03.941030 [ 9678 ] {909a5ee8-6fec-43c9-9c8c-c27f81ca992b} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37036) (comment: 02098_with_types_use_header.sh) (in query: DROP DATABASE IF EXISTS test_3kvgwciy ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:41:03.944066 [ 9678 ] {909a5ee8-6fec-43c9-9c8c-c27f81ca992b} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:03.964877 [ 7565 ] {51d3c364-c55f-4d32-a066-aa97b8c366a0} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37044) (comment: 02098_with_types_use_header.sh) (in query: DROP DATABASE IF EXISTS test_3kvgwciy ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:41:03.967609 [ 7565 ] {51d3c364-c55f-4d32-a066-aa97b8c366a0} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:03.978418 [ 18542 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:04.264218 [ 3071 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:04.443486 [ 3438 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:04.443548 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:04.609919 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:05.100331 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:05.198903 [ 4675 ] {968dff64-e52a-4c1a-8981-21e10bc44649} executeQuery: Code: 69. DB::Exception: Second argument of function fuzzBits must be from `0.0` to `1.0`: In scope SELECT fuzzBits('string', -1.). (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37664) (comment: 01284_fuzz_bits.sql) (in query: SELECT fuzzBits('string', -1.0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. DB::(anonymous namespace)::FunctionFuzzBits::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fb68470 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 2025.10.23 23:41:05.200385 [ 4675 ] {968dff64-e52a-4c1a-8981-21e10bc44649} TCPHandler: Code: 69. DB::Exception: Second argument of function fuzzBits must be from `0.0` to `1.0`: In scope SELECT fuzzBits('string', -1.). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. DB::(anonymous namespace)::FunctionFuzzBits::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fb68470 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 2025.10.23 23:41:05.265045 [ 3473 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:05.421920 [ 4675 ] {e66b08b1-6138-4c90-889b-58de22cd01b8} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=753). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37664) (comment: 01284_fuzz_bits.sql) (in query: SELECT length(fuzzBits(randomString(100), 0.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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:41:05.423606 [ 4675 ] {e66b08b1-6138-4c90-889b-58de22cd01b8} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=753). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:41:05.444439 [ 3216 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:05.491648 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:05.827444 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:06.140749 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:06.265867 [ 3256 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:06.445153 [ 3371 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:06.554409 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:06.936145 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:07.204800 [ 18540 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:07.266537 [ 3200 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:07.445936 [ 3535 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:07.459682 [ 3933 ] {5f1594de-c3c2-47e3-ae9c-bdcfaf9c7c12} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44486) (comment: 02156_storage_merge_prewhere_not_ready_set_bug.sql) (in query: DROP DATABASE IF EXISTS test_lrtx7pgv ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000003494763c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 13. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 14. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 21. ? @ 0x00007f100c857ac3 22. ? @ 0x00007f100c8e9850 2025.10.23 23:41:07.462281 [ 3933 ] {5f1594de-c3c2-47e3-ae9c-bdcfaf9c7c12} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000003494763c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 13. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 14. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 21. ? @ 0x00007f100c857ac3 22. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:07.584528 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:07.995877 [ 4745 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:08.241911 [ 4745 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:08.285160 [ 3149 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:08.447258 [ 3137 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:08.633250 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:09.022372 [ 18540 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:09.286179 [ 3081 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:09.363060 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:09.448192 [ 3185 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:09.685792 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:10.077130 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:10.287289 [ 3104 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:10.448929 [ 3157 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:10.460767 [ 4745 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:10.623488 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:10.717363 [ 18540 ] {7cd95c22-9f5e-4803-8a59-feca65e2f7bf} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44538) (comment: 02969_functions_to_subcolumns_if_null.sql) (in query: DROP DATABASE IF EXISTS test_9bi1hyfb ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:41:10.719667 [ 18540 ] {7cd95c22-9f5e-4803-8a59-feca65e2f7bf} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:10.731898 [ 9678 ] {728ca19d-207c-4a10-9938-1e44ad45559b} executeQuery: Code: 43. DB::Exception: Invalid projection column with type Nothing. In scope SELECT JSONExtractKeysAndValuesRaw(arrayJoin([])). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42648) (comment: 02317_functions_with_nothing.sql) (in query: SELECT JSONExtractKeysAndValuesRaw(arrayJoin([]));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5627: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003343cfd7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034cf4284 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 22. ? @ 0x00007f100c857ac3 23. ? @ 0x00007f100c8e9850 2025.10.23 23:41:10.733195 [ 9678 ] {728ca19d-207c-4a10-9938-1e44ad45559b} TCPHandler: Code: 43. DB::Exception: Invalid projection column with type Nothing. In scope SELECT JSONExtractKeysAndValuesRaw(arrayJoin([])). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5627: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003343cfd7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034cf4284 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 22. ? @ 0x00007f100c857ac3 23. ? @ 0x00007f100c8e9850 2025.10.23 23:41:10.741679 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:10.754436 [ 9678 ] {5862d47c-299d-426b-b0ed-15d70664d368} executeQuery: Code: 43. DB::Exception: Invalid projection column with type Nothing. In scope SELECT JSONHas(arrayJoin([])). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42648) (comment: 02317_functions_with_nothing.sql) (in query: SELECT JSONHas(arrayJoin([]));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5627: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003343cfd7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034cf4284 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 22. ? @ 0x00007f100c857ac3 23. ? @ 0x00007f100c8e9850 2025.10.23 23:41:10.756015 [ 9678 ] {5862d47c-299d-426b-b0ed-15d70664d368} TCPHandler: Code: 43. DB::Exception: Invalid projection column with type Nothing. In scope SELECT JSONHas(arrayJoin([])). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5627: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003343cfd7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034cf4284 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 22. ? @ 0x00007f100c857ac3 23. ? @ 0x00007f100c8e9850 2025.10.23 23:41:10.776237 [ 9678 ] {c5940900-045b-46fb-8b8f-e55207201607} executeQuery: Code: 43. DB::Exception: Invalid projection column with type Nothing. In scope SELECT isValidJSON(arrayJoin([])). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42648) (comment: 02317_functions_with_nothing.sql) (in query: SELECT isValidJSON(arrayJoin([]));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5627: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003343cfd7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034cf4284 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 22. ? @ 0x00007f100c857ac3 23. ? @ 0x00007f100c8e9850 2025.10.23 23:41:10.778209 [ 9678 ] {c5940900-045b-46fb-8b8f-e55207201607} TCPHandler: Code: 43. DB::Exception: Invalid projection column with type Nothing. In scope SELECT isValidJSON(arrayJoin([])). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5627: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003343cfd7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034cf4284 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 22. ? @ 0x00007f100c857ac3 23. ? @ 0x00007f100c8e9850 2025.10.23 23:41:10.808983 [ 9678 ] {f4d90a44-0bf6-406f-b67a-040042ea35a4} executeQuery: Code: 43. DB::Exception: Invalid projection column with type Nothing. In scope SELECT concat(arrayJoin([]), arrayJoin([NULL, ''])). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42648) (comment: 02317_functions_with_nothing.sql) (in query: SELECT concat(arrayJoin([]), arrayJoin([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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5627: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003343cfd7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034cf4284 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 22. ? @ 0x00007f100c857ac3 23. ? @ 0x00007f100c8e9850 2025.10.23 23:41:10.810941 [ 9678 ] {f4d90a44-0bf6-406f-b67a-040042ea35a4} TCPHandler: Code: 43. DB::Exception: Invalid projection column with type Nothing. In scope SELECT concat(arrayJoin([]), arrayJoin([NULL, ''])). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5627: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003343cfd7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034cf4284 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 22. ? @ 0x00007f100c857ac3 23. ? @ 0x00007f100c8e9850 2025.10.23 23:41:10.849622 [ 9678 ] {d6f83ac5-bb8b-4f5d-ae7b-47440a2bcd15} executeQuery: Code: 43. DB::Exception: Invalid projection column with type Nothing. In scope SELECT arrayJoin([]) + arrayJoin([NULL, 1]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42648) (comment: 02317_functions_with_nothing.sql) (in query: SELECT plus(arrayJoin([]), arrayJoin([NULL, 1]));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5627: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003343cfd7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034cf4284 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 22. ? @ 0x00007f100c857ac3 23. ? @ 0x00007f100c8e9850 2025.10.23 23:41:10.851461 [ 9678 ] {d6f83ac5-bb8b-4f5d-ae7b-47440a2bcd15} TCPHandler: Code: 43. DB::Exception: Invalid projection column with type Nothing. In scope SELECT arrayJoin([]) + arrayJoin([NULL, 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5627: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003343cfd7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034cf4284 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 22. ? @ 0x00007f100c857ac3 23. ? @ 0x00007f100c8e9850 2025.10.23 23:41:10.879981 [ 9678 ] {c2ae61a5-7ebb-4743-b51b-73077aa7ff9b} executeQuery: Code: 43. DB::Exception: Invalid projection column with type Nothing. In scope SELECT sipHash64(arrayJoin([]), [NULL], arrayJoin(['', NULL, '', NULL])). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42648) (comment: 02317_functions_with_nothing.sql) (in query: SELECT sipHash64(arrayJoin([]), [NULL], arrayJoin(['', NULL, '', NULL]));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5627: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003343cfd7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034cf4284 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 22. ? @ 0x00007f100c857ac3 23. ? @ 0x00007f100c8e9850 2025.10.23 23:41:10.881894 [ 9678 ] {c2ae61a5-7ebb-4743-b51b-73077aa7ff9b} TCPHandler: Code: 43. DB::Exception: Invalid projection column with type Nothing. In scope SELECT sipHash64(arrayJoin([]), [NULL], arrayJoin(['', NULL, '', NULL])). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5627: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003343cfd7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034cf4284 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 22. ? @ 0x00007f100c857ac3 23. ? @ 0x00007f100c8e9850 2025.10.23 23:41:11.233115 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:11.288207 [ 3388 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:11.450017 [ 3198 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:11.500182 [ 3109 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTablesParallel(std::vector, std::allocator>>) @ 0x00000000339c8298 8. ./contrib/llvm-project/libcxx/include/vector:438: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000339c92ee 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000339ec17f 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:11.534482 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:11.783158 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:12.077435 [ 2903 ] {8c0e3926-57ee-4d5c-b40c-56be7b249cb3} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42774) (comment: 01825_type_json_9.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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000003159b57b 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337550f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e79fb4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:12.177622 [ 2903 ] {8c0e3926-57ee-4d5c-b40c-56be7b249cb3} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000003159b57b 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337550f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e79fb4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:12.288953 [ 3279 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:12.317820 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:12.451493 [ 3541 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:12.607775 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:12.807667 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:13.289893 [ 3501 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:13.367377 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:13.452833 [ 3063 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:13.661666 [ 4752 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:13.997616 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:14.290632 [ 3220 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:14.405424 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:14.453517 [ 3283 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:14.717292 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:15.100210 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:15.294217 [ 3120 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:15.311851 [ 4752 ] {463d4cf0-9c8b-4f86-89b9-73e964c6dcd4} executeQuery: Code: 47. DB::Exception: Qualified matcher abc.* does not find table. In scope SELECT abc.*. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42864) (comment: 01333_select_abc_asterisk.sql) (in query: --error: should be failed for abc.*; select abc.*;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1789: DB::QueryAnalyzer::resolveQualifiedMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033495ccb 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334caa96 6. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344f323 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 9. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 27. ? @ 0x00007f100c857ac3 28. ? @ 0x00007f100c8e9850 2025.10.23 23:41:15.313254 [ 4752 ] {463d4cf0-9c8b-4f86-89b9-73e964c6dcd4} TCPHandler: Code: 47. DB::Exception: Qualified matcher abc.* does not find table. In scope SELECT abc.*. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1789: DB::QueryAnalyzer::resolveQualifiedMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033495ccb 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334caa96 6. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344f323 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 9. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 27. ? @ 0x00007f100c857ac3 28. ? @ 0x00007f100c8e9850 2025.10.23 23:41:15.333645 [ 4752 ] {a1c9f240-d309-4457-9da6-70a26a6eb6f7} executeQuery: Code: 47. DB::Exception: Qualified matcher abc.* does not find table. In scope SELECT *, abc.*. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42864) (comment: 01333_select_abc_asterisk.sql) (in query: select *, abc.*;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1789: DB::QueryAnalyzer::resolveQualifiedMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033495ccb 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334caa96 6. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344f323 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 9. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 27. ? @ 0x00007f100c857ac3 28. ? @ 0x00007f100c8e9850 2025.10.23 23:41:15.334780 [ 4752 ] {a1c9f240-d309-4457-9da6-70a26a6eb6f7} TCPHandler: Code: 47. DB::Exception: Qualified matcher abc.* does not find table. In scope SELECT *, abc.*. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1789: DB::QueryAnalyzer::resolveQualifiedMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033495ccb 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334caa96 6. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344f323 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 9. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 27. ? @ 0x00007f100c857ac3 28. ? @ 0x00007f100c8e9850 2025.10.23 23:41:15.350255 [ 4752 ] {79430cb8-ab89-4de1-8e35-e4d8096e0706} executeQuery: Code: 47. DB::Exception: Qualified matcher abc.* does not find table. In scope SELECT abc.*, *. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42864) (comment: 01333_select_abc_asterisk.sql) (in query: select abc.*, *;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1789: DB::QueryAnalyzer::resolveQualifiedMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033495ccb 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334caa96 6. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344f323 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 9. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 27. ? @ 0x00007f100c857ac3 28. ? @ 0x00007f100c8e9850 2025.10.23 23:41:15.357126 [ 4752 ] {79430cb8-ab89-4de1-8e35-e4d8096e0706} TCPHandler: Code: 47. DB::Exception: Qualified matcher abc.* does not find table. In scope SELECT abc.*, *. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1789: DB::QueryAnalyzer::resolveQualifiedMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033495ccb 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334caa96 6. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344f323 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 9. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 27. ? @ 0x00007f100c857ac3 28. ? @ 0x00007f100c8e9850 2025.10.23 23:41:15.454394 [ 3308 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:15.499660 [ 4752 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:15.787751 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:15.976435 [ 7652 ] {9eb10adb-0265-4f51-a48b-ff805cc8ff9e} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42826) (comment: 02989_variant_comparison.sql) (in query: select v1, v2, v1 > v2 from test order by v1, v2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:41:15.980786 [ 7652 ] {9eb10adb-0265-4f51-a48b-ff805cc8ff9e} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:41:16.147845 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:16.294915 [ 3223 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:16.455184 [ 3378 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:16.573028 [ 4752 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:16.982896 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:17.295738 [ 3178 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:17.401678 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:17.456808 [ 3402 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:17.670155 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:18.072262 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:18.300935 [ 3061 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:18.458421 [ 3302 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:18.492319 [ 9453 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:18.594082 [ 4752 ] {cf7e1753-9ca1-4405-91a9-7d36140406e1} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59108) (comment: 01721_dictionary_decimal_p_s.sql) (in query: drop database if exists db_01721;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349417ab 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>>>&) @ 0x0000000034947b8d 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:18.597078 [ 4752 ] {cf7e1753-9ca1-4405-91a9-7d36140406e1} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349417ab 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>>>&) @ 0x0000000034947b8d 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:18.836021 [ 4752 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:19.158962 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:19.304532 [ 3107 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:19.461711 [ 3226 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:19.590506 [ 4752 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:19.881476 [ 4752 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:20.251327 [ 9453 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:20.305184 [ 3168 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:20.462694 [ 3087 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:20.735474 [ 4752 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:21.016240 [ 4752 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:21.283438 [ 4752 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:21.306297 [ 3305 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:21.465905 [ 3367 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:21.601606 [ 9557 ] {3103ec5b-47f4-4f39-a9dc-7eaf5e889066} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=766). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59218) (comment: 00392_enum_nested_alter.sql) (in query: SELECT * FROM enum_nested_alter 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:41:21.605058 [ 9557 ] {3103ec5b-47f4-4f39-a9dc-7eaf5e889066} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=766). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:41:21.818847 [ 4752 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:22.206534 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:22.307032 [ 3155 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:22.330439 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:22.466540 [ 3405 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:22.870151 [ 4752 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:23.282681 [ 9453 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:23.307838 [ 3392 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:23.467287 [ 3452 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:23.469683 [ 9453 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:23.910705 [ 18542 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:24.322961 [ 9453 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:24.346422 [ 3306 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:24.468429 [ 3331 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:24.519359 [ 9453 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:24.542967 [ 2904 ] {4479fe75-3f61-4c9d-96df-d78120136224} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=749). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59164) (comment: 02496_format_datetime_in_joda_syntax.sql) (in query: with '2018-01-12 22:33:44.55' as s, toDateTime64(s, 6) as datetime64 SELECT formatDateTimeInJodaSyntax(datetime64, 'SSSSS');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:41:24.546946 [ 2904 ] {4479fe75-3f61-4c9d-96df-d78120136224} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=749). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:41:24.731906 [ 3120 ] {} test_3.table1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.10.23 23:41:24.732134 [ 3537 ] {} test_3.`02691_drop_column_replicated` (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.10.23 23:41:24.732242 [ 3062 ] {} test_3.rmt (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.10.23 23:41:24.732722 [ 3504 ] {} test_15.r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.10.23 23:41:24.733454 [ 3316 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000003cc8de51 3. ./src/Common/ZooKeeper/IKeeper.h:509: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003cd16a3e 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1383: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x000000003cd1a472 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x000000003cbf5306 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:610: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x000000003cbf42db 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000003cbf676b 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003cbf5ab3 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x000000003a0eb80c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889e7df 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:24.733457 [ 3057 ] {} test_3.rmt (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Session expired (fault injected on send). (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000003a21d8b1 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEES0_NS_5ErrorEOS5_ @ 0x000000003cd2cd64 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1654: Coordination::ZooKeeper::maybeInjectSendFault() @ 0x000000003cd17122 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003cd165e8 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003cd2369f 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe6e6d 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe5f26 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe84e7 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000003cbe7761 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x000000003a061e9e 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x000000003a04fe19 13. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a041419 14. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:50: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a03dd98 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003a06697f 16. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 18. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 21. ? @ 0x00007f100c857ac3 22. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:24.733954 [ 3133 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000003cc8de51 3. ./src/Common/ZooKeeper/IKeeper.h:509: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003cd16a3e 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003cd2369f 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe6e6d 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe5f26 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe84e7 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe81ea 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000003a10064e 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000003889f11d 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f9f 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:24.993893 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:25.347158 [ 3365 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:25.367524 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:25.469261 [ 3168 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:25.575957 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:26.037171 [ 18540 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:26.347994 [ 3559 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:26.399205 [ 9678 ] {fa86d326-6b14-4df3-8781-03bc70f7b6d2} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=4). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:33424) (comment: 02933_group_by_memory_usage.sh) (in query: select ProfileEvents['ExternalAggregationWritePart'] from system.query_log where current_database = currentDatabase() and type = 'QueryFinish' and query_id = 'group-by-mem-usage-test_11' and event_date >= today() - 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:41:26.408378 [ 9678 ] {fa86d326-6b14-4df3-8781-03bc70f7b6d2} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:41:26.440181 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:26.469992 [ 3337 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:26.511568 [ 18542 ] {269f49b4-86da-47de-893f-a62228b8e395} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 11 ('#'): #. Unrecognized token: '#'. (SYNTAX_ERROR) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:43920) (comment: 02192_comment_error.sh) (in query: select 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000840a53e 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) @ 0x000000003d1bceea 4. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003d1bd031 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358ad0d2 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 7. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 8. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 2025.10.23 23:41:26.513740 [ 18542 ] {269f49b4-86da-47de-893f-a62228b8e395} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error: failed at position 11 ('#'): #. Unrecognized token: '#'. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000840a53e 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) @ 0x000000003d1bceea 4. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003d1bd031 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358ad0d2 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 7. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 8. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:26.650508 [ 18542 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:26.849787 [ 9453 ] {226adcdf-2e46-4d79-ba3c-9d8fc680e8b2} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, jobs=0): (while reading column a): (while reading from part /var/lib/clickhouse/store/f5d/f5d68477-a685-4df6-927d-71afd40e94ba/all_1_1_0/ in table test_3.hypothesis_test_test3 (f5d68477-a685-4df6-927d-71afd40e94ba) located on disk default of type local, from mark 1 with max_rows_to_read = 4): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59444) (comment: 01624_soft_constraints.sh) (in query: SELECT count() FROM hypothesis_test_test3 WHERE a <= b 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000003075641a 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030755c60 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000307521d1 9. ./src/IO/AsynchronousReader.h:48: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000003073084e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000003073196f 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./src/IO/ReadBuffer.h:106: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x00000000320e80f8 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x00000000320ec44e 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x00000000320ed00d 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000032795b67 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000032642210 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:216: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039c8e35d 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:0: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ce6eb1 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039cb3032 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039cd6816 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000039ccef53 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000039d4a566 23. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000003bfe52b4 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:206: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d3c6b0 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf89b85 26. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 27. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 31. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 2025.10.23 23:41:26.853849 [ 9453 ] {226adcdf-2e46-4d79-ba3c-9d8fc680e8b2} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, jobs=0): (while reading column a): (while reading from part /var/lib/clickhouse/store/f5d/f5d68477-a685-4df6-927d-71afd40e94ba/all_1_1_0/ in table test_3.hypothesis_test_test3 (f5d68477-a685-4df6-927d-71afd40e94ba) located on disk default of type local, from mark 1 with max_rows_to_read = 4): 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000003075641a 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030755c60 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000307521d1 9. ./src/IO/AsynchronousReader.h:48: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000003073084e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000003073196f 11. DB::ReadBuffer::next() @ 0x00000000095b468f 12. ./src/IO/ReadBuffer.h:106: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x00000000320e80f8 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x00000000320ec44e 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x00000000320ed00d 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000032795b67 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000032642210 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:216: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039c8e35d 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:0: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ce6eb1 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039cb3032 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039cd6816 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000039ccef53 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000039d4a566 23. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000003bfe52b4 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:206: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d3c6b0 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf89b85 26. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 27. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 31. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 2025.10.23 23:41:27.130076 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:27.356650 [ 3118 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:27.470727 [ 3140 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:27.504860 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:27.725698 [ 9453 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:28.217981 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:28.251001 [ 3655 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {d7361de3-cb90-4044-830f-20b9d940375a::202510_1_61_12}: 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 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) @ 0x0000000039c89948 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000003999bfb7 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 @ 0x00000000399942f0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000039d15c04 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&) @ 0x0000000039d20399 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) @ 0x0000000039d1c606 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000396308a4 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x00000000396235dd 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000003963b3e0 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x00000000396504a0 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3c455d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:28.357237 [ 3266 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:28.471440 [ 3250 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:28.553914 [ 4745 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:28.782488 [ 4745 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:29.275100 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:29.357903 [ 3158 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:29.472260 [ 3076 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:29.603579 [ 4745 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:29.827396 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:30.329340 [ 4745 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:30.358575 [ 3222 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:30.365454 [ 9678 ] {670cc444-1250-440e-ba7c-071b795173c8} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:33586) (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000003159b57b 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337550f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e79fb4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:30.368606 [ 9678 ] {670cc444-1250-440e-ba7c-071b795173c8} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000003159b57b 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337550f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e79fb4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:30.473226 [ 3468 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:30.646495 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:30.866977 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:31.354990 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:31.359415 [ 3394 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:31.378782 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:31.473969 [ 3566 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:31.805181 [ 9453 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:31.933292 [ 9453 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:32.360126 [ 3436 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:32.416695 [ 9453 ] {2260eeba-b6a9-40d1-950c-9857214ce1f4} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56468) (comment: 02915_input_table_function_in_subquery.sh) (in query: DROP DATABASE IF EXISTS test_gnarfto0 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:41:32.419060 [ 9453 ] {2260eeba-b6a9-40d1-950c-9857214ce1f4} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:32.434024 [ 4694 ] {c7b7a16f-08f3-4f97-b9d0-9f36b93edb16} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56470) (comment: 02915_input_table_function_in_subquery.sh) (in query: DROP DATABASE IF EXISTS test_gnarfto0 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:41:32.436397 [ 4694 ] {c7b7a16f-08f3-4f97-b9d0-9f36b93edb16} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:32.461240 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:32.474736 [ 3492 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:32.928654 [ 9453 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:33.080217 [ 9453 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:33.360783 [ 3060 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:33.475545 [ 3177 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:33.540031 [ 9453 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:34.007569 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:34.159090 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:34.162818 [ 9453 ] {8c6e8c2f-2d15-4fb7-8b9e-d5b7206c0e6b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=749). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:33746) (comment: 00951_ngram_search.sql) (in query: select round(1000 * ngramSearchUTF8(materialize('абв'), '')) from system.numbers limit 5;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:41:34.166271 [ 9453 ] {8c6e8c2f-2d15-4fb7-8b9e-d5b7206c0e6b} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=749). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:41:34.361506 [ 3166 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:34.476685 [ 3508 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:34.552991 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:35.073371 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:35.213899 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:35.362245 [ 3260 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:35.477561 [ 3498 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:35.662649 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:36.108092 [ 9453 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:36.274790 [ 9453 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:36.363352 [ 3294 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:36.478718 [ 3233 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:36.891067 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:37.205467 [ 9453 ] {42e0c39b-cc00-49ec-a035-b77f305fa10b} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44764) (comment: 01825_type_json_in_array.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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000003159b57b 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337550f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e79fb4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:37.207541 [ 9453 ] {42e0c39b-cc00-49ec-a035-b77f305fa10b} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000003159b57b 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337550f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e79fb4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:37.224660 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:37.331262 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:37.364328 [ 3302 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:37.480077 [ 3219 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:37.982686 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:38.328440 [ 18545 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:38.365342 [ 3343 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:38.385282 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:38.481885 [ 3143 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:38.642965 [ 9453 ] {6e92b375-f4e8-4204-a233-b85c8435fe18} executeQuery: Code: 524. DB::Exception: The following alter commands: 'MODIFY COLUMN `value3` UInt64' will modify data on disk, but setting `allow_non_metadata_alters` is disabled. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44802) (comment: 01413_allow_non_metadata_alters.sql) (in query: ALTER TABLE non_metadata_alters MODIFY COLUMN value3 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3225: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039776a5c 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034866235 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003485e550 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:41:38.644395 [ 9453 ] {6e92b375-f4e8-4204-a233-b85c8435fe18} TCPHandler: Code: 524. DB::Exception: The following alter commands: 'MODIFY COLUMN `value3` UInt64' will modify data on disk, but setting `allow_non_metadata_alters` is disabled. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3225: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039776a5c 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034866235 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003485e550 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:41:38.659347 [ 9453 ] {98bff614-4179-42b7-ac93-c663ed677da4} executeQuery: Code: 524. DB::Exception: The following alter commands: 'MODIFY COLUMN `value1` UInt32' will modify data on disk, but setting `allow_non_metadata_alters` is disabled. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44802) (comment: 01413_allow_non_metadata_alters.sql) (in query: ALTER TABLE non_metadata_alters MODIFY COLUMN value1 UInt32;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3225: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039776a5c 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034866235 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003485e550 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:41:38.751959 [ 9453 ] {98bff614-4179-42b7-ac93-c663ed677da4} TCPHandler: Code: 524. DB::Exception: The following alter commands: 'MODIFY COLUMN `value1` UInt32' will modify data on disk, but setting `allow_non_metadata_alters` is disabled. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3225: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039776a5c 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034866235 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003485e550 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:41:38.818885 [ 9453 ] {4a8a6590-5f64-4b46-98e2-43a8a4bebb6a} executeQuery: Code: 524. DB::Exception: The following alter commands: 'MODIFY COLUMN `value4` Date' will modify data on disk, but setting `allow_non_metadata_alters` is disabled. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44802) (comment: 01413_allow_non_metadata_alters.sql) (in query: ALTER TABLE non_metadata_alters MODIFY COLUMN value4 Date;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3225: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039776a5c 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034866235 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003485e550 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:41:38.879311 [ 9453 ] {4a8a6590-5f64-4b46-98e2-43a8a4bebb6a} TCPHandler: Code: 524. DB::Exception: The following alter commands: 'MODIFY COLUMN `value4` Date' will modify data on disk, but setting `allow_non_metadata_alters` is disabled. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3225: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039776a5c 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034866235 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003485e550 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:41:38.931966 [ 9453 ] {988bff6a-ba85-43a0-9b9f-92c13ccba6e4} executeQuery: Code: 524. DB::Exception: The following alter commands: 'DROP COLUMN value4' will modify data on disk, but setting `allow_non_metadata_alters` is disabled. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44802) (comment: 01413_allow_non_metadata_alters.sql) (in query: ALTER TABLE non_metadata_alters DROP COLUMN value4;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3225: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039776a5c 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034866235 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003485e550 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:41:38.935909 [ 9453 ] {988bff6a-ba85-43a0-9b9f-92c13ccba6e4} TCPHandler: Code: 524. DB::Exception: The following alter commands: 'DROP COLUMN value4' will modify data on disk, but setting `allow_non_metadata_alters` is disabled. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3225: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039776a5c 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034866235 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003485e550 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:41:38.956453 [ 9453 ] {35c1f05d-a51c-4e95-9cac-608b98603ed5} executeQuery: Code: 524. DB::Exception: The following alter commands: 'MODIFY COLUMN `value2` Enum8('x' = 5, 'y' = 6)' will modify data on disk, but setting `allow_non_metadata_alters` is disabled. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44802) (comment: 01413_allow_non_metadata_alters.sql) (in query: ALTER TABLE non_metadata_alters MODIFY COLUMN value2 Enum8('x' = 5, 'y' = 6);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3225: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039776a5c 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034866235 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003485e550 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:41:38.957831 [ 9453 ] {35c1f05d-a51c-4e95-9cac-608b98603ed5} TCPHandler: Code: 524. DB::Exception: The following alter commands: 'MODIFY COLUMN `value2` Enum8('x' = 5, 'y' = 6)' will modify data on disk, but setting `allow_non_metadata_alters` is disabled. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3225: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039776a5c 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034866235 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003485e550 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:41:38.974543 [ 9453 ] {2377a1be-9c06-43ef-9286-88c684f8ae12} executeQuery: Code: 524. DB::Exception: The following alter commands: 'RENAME COLUMN value4 TO renamed_value4' will modify data on disk, but setting `allow_non_metadata_alters` is disabled. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44802) (comment: 01413_allow_non_metadata_alters.sql) (in query: ALTER TABLE non_metadata_alters RENAME COLUMN value4 TO renamed_value4;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3225: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039776a5c 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034866235 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003485e550 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:41:38.982346 [ 9453 ] {2377a1be-9c06-43ef-9286-88c684f8ae12} TCPHandler: Code: 524. DB::Exception: The following alter commands: 'RENAME COLUMN value4 TO renamed_value4' will modify data on disk, but setting `allow_non_metadata_alters` is disabled. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3225: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039776a5c 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034866235 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003485e550 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:41:39.036503 [ 9453 ] {4f4b3eda-f25e-4a8a-b92c-24b9e994fc51} executeQuery: Code: 524. DB::Exception: The following alter commands: 'MATERIALIZE TTL' will modify data on disk, but setting `allow_non_metadata_alters` is disabled. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44802) (comment: 01413_allow_non_metadata_alters.sql) (in query: ALTER TABLE non_metadata_alters MODIFY COLUMN value3 UInt16 TTL value5 + INTERVAL 5 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3225: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039776a5c 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034866235 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003485e550 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:41:39.037848 [ 9453 ] {4f4b3eda-f25e-4a8a-b92c-24b9e994fc51} TCPHandler: Code: 524. DB::Exception: The following alter commands: 'MATERIALIZE TTL' will modify data on disk, but setting `allow_non_metadata_alters` is disabled. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3225: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039776a5c 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034866235 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003485e550 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:41:39.071199 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:39.366227 [ 3458 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:39.373480 [ 4752 ] {a4bc17c9-42ed-4de2-b01a-2d5c78796c21} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01854_HTTP_dict_decompression.sh) (in query: /* ddl_entry=query-0000000073 */ TRUNCATE DICTIONARY IF EXISTS test_11.test_table_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349417ab 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003395fc9e 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000033958fac 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ad726d 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a52a3c 14. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:222: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003493e6e9 15. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 16. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 17. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 20. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 21. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 22. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 2025.10.23 23:41:39.411323 [ 4752 ] {a4bc17c9-42ed-4de2-b01a-2d5c78796c21} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:50724) (comment: 01854_HTTP_dict_decompression.sh) (in query: drop dictionary if exists test_table_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349417ab 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003395fc9e 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000033958fac 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ad726d 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a52a3c 14. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:222: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003493e6e9 15. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 16. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 17. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 20. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 21. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 22. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 2025.10.23 23:41:39.413919 [ 4752 ] {a4bc17c9-42ed-4de2-b01a-2d5c78796c21} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349417ab 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003395fc9e 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000033958fac 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ad726d 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a52a3c 14. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:222: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003493e6e9 15. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 16. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 17. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 20. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 21. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 22. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:39.447680 [ 18545 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:39.482629 [ 3212 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:39.484602 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:40.114505 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:40.366908 [ 3409 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:40.483497 [ 3132 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:40.500246 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:40.521172 [ 18545 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:41.154074 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:41.367607 [ 3109 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:41.484375 [ 3317 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:41.560672 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:41.592632 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:42.174213 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:42.368451 [ 3403 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:42.485130 [ 3559 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:42.618012 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:42.674108 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:43.246188 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:43.369224 [ 3410 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:43.485914 [ 3395 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:43.522166 [ 18545 ] {805fecf6-9959-4757-af0c-cc57bcaa137b} executeQuery: Code: 53. DB::Exception: Cannot convert string 'default.table_name' to type Int32: While processing n IN ('default.table_name') AS m: default expression and column type are incompatible. (TYPE_MISMATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44908) (comment: 02433_default_expression_operator_in.sql) (in query: -- Ensure that a table name cannot be passed to IN as string literal create table test (n int, m default n in 'default.table_name') 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&&) @ 0x000000000df4df8d 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:559: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357d8570 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357ce96d 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&) @ 0x00000000357d97c5 7. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:124: DB::Block DB::createBlockFromCollection(DB::Array const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, bool) @ 0x0000000033b39335 8. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::makeExplicitSet(DB::ASTFunction const*, DB::ActionsDAG const&, std::shared_ptr, DB::PreparedSets&) @ 0x0000000033b03be2 9. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1492: DB::ActionsMatcher::makeSet(DB::ASTFunction const&, DB::ActionsMatcher::Data&, bool) @ 0x0000000033b35268 10. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b1d35e 11. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b1a2f5 12. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000033af7075 13. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000033a7619f 14. ./contrib/llvm-project/libcxx/include/string:1499: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x0000000033aa9f33 15. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x0000000033aaabd2 16. ./build_docker/./src/Storages/ColumnsDescription.cpp:986: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000380ffc91 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000348a82f8 18. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348af396 19. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cde07 20. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 30. ? @ 0x00007f100c857ac3 31. ? @ 0x00007f100c8e9850 2025.10.23 23:41:43.523613 [ 18545 ] {805fecf6-9959-4757-af0c-cc57bcaa137b} TCPHandler: Code: 53. DB::Exception: Cannot convert string 'default.table_name' to type Int32: While processing n IN ('default.table_name') AS m: default expression and column type are incompatible. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&&) @ 0x000000000df4df8d 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:559: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357d8570 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357ce96d 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&) @ 0x00000000357d97c5 7. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:124: DB::Block DB::createBlockFromCollection(DB::Array const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, bool) @ 0x0000000033b39335 8. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::makeExplicitSet(DB::ASTFunction const*, DB::ActionsDAG const&, std::shared_ptr, DB::PreparedSets&) @ 0x0000000033b03be2 9. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1492: DB::ActionsMatcher::makeSet(DB::ASTFunction const&, DB::ActionsMatcher::Data&, bool) @ 0x0000000033b35268 10. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b1d35e 11. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b1a2f5 12. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000033af7075 13. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000033a7619f 14. ./contrib/llvm-project/libcxx/include/string:1499: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x0000000033aa9f33 15. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x0000000033aaabd2 16. ./build_docker/./src/Storages/ColumnsDescription.cpp:986: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000380ffc91 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000348a82f8 18. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348af396 19. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cde07 20. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 30. ? @ 0x00007f100c857ac3 31. ? @ 0x00007f100c8e9850 2025.10.23 23:41:43.628805 [ 18545 ] {518fb077-d6c0-47e3-a645-3c1cd57d7450} executeQuery: Code: 53. DB::Exception: Cannot convert string 'default.table_name' to type Int32: While processing n IN ('default.table_name') AS m: default expression and column type are incompatible. (TYPE_MISMATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44908) (comment: 02433_default_expression_operator_in.sql) (in query: create table test (n int, m default in(n, 'default.table_name')) 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&&) @ 0x000000000df4df8d 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:559: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357d8570 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357ce96d 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&) @ 0x00000000357d97c5 7. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:124: DB::Block DB::createBlockFromCollection(DB::Array const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, bool) @ 0x0000000033b39335 8. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::makeExplicitSet(DB::ASTFunction const*, DB::ActionsDAG const&, std::shared_ptr, DB::PreparedSets&) @ 0x0000000033b03be2 9. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1492: DB::ActionsMatcher::makeSet(DB::ASTFunction const&, DB::ActionsMatcher::Data&, bool) @ 0x0000000033b35268 10. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b1d35e 11. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b1a2f5 12. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000033af7075 13. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000033a7619f 14. ./contrib/llvm-project/libcxx/include/string:1499: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x0000000033aa9f33 15. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x0000000033aaabd2 16. ./build_docker/./src/Storages/ColumnsDescription.cpp:986: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000380ffc91 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000348a82f8 18. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348af396 19. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cde07 20. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 30. ? @ 0x00007f100c857ac3 31. ? @ 0x00007f100c8e9850 2025.10.23 23:41:43.630258 [ 18545 ] {518fb077-d6c0-47e3-a645-3c1cd57d7450} TCPHandler: Code: 53. DB::Exception: Cannot convert string 'default.table_name' to type Int32: While processing n IN ('default.table_name') AS m: default expression and column type are incompatible. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&&) @ 0x000000000df4df8d 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:559: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357d8570 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357ce96d 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&) @ 0x00000000357d97c5 7. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:124: DB::Block DB::createBlockFromCollection(DB::Array const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, bool) @ 0x0000000033b39335 8. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::makeExplicitSet(DB::ASTFunction const*, DB::ActionsDAG const&, std::shared_ptr, DB::PreparedSets&) @ 0x0000000033b03be2 9. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1492: DB::ActionsMatcher::makeSet(DB::ASTFunction const&, DB::ActionsMatcher::Data&, bool) @ 0x0000000033b35268 10. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b1d35e 11. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b1a2f5 12. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000033af7075 13. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000033a7619f 14. ./contrib/llvm-project/libcxx/include/string:1499: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x0000000033aa9f33 15. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x0000000033aaabd2 16. ./build_docker/./src/Storages/ColumnsDescription.cpp:986: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000380ffc91 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000348a82f8 18. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348af396 19. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cde07 20. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 30. ? @ 0x00007f100c857ac3 31. ? @ 0x00007f100c8e9850 2025.10.23 23:41:43.748647 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:43.751901 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:43.997540 [ 18545 ] {8c6fd12a-1157-4ebc-b463-d1e46fee5009} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:50756) (comment: 02433_default_expression_operator_in.sql) (in query: DROP DATABASE IF EXISTS test_htsh3pw2 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:41:44.000111 [ 18545 ] {8c6fd12a-1157-4ebc-b463-d1e46fee5009} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:44.017225 [ 7652 ] {eab3b3f6-614f-477c-ad12-5eca22aa5274} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:50770) (comment: 02433_default_expression_operator_in.sql) (in query: DROP DATABASE IF EXISTS test_htsh3pw2 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:41:44.019755 [ 7652 ] {eab3b3f6-614f-477c-ad12-5eca22aa5274} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:44.311378 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:44.389651 [ 3475 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:44.486782 [ 3176 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:44.786026 [ 18545 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:44.833793 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:45.323224 [ 18545 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:45.390457 [ 3488 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:45.487932 [ 3236 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:45.859283 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:45.920218 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:46.377003 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:46.391148 [ 3204 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:46.488994 [ 3148 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:46.875468 [ 2903 ] {ddf17973-8b2d-48a5-aa05-561368d5d996} executeQuery: Code: 47. DB::Exception: Unknown identifier 'xyz' inside COLUMNS matcher. In scope Scope node SELECT COLUMNS(bar, foo, xyz) APPLY length FROM test Identifier lookup to resolve state 2 Identifier foo EXPRESSION resolve result test_us7va76b.test.foo place JOIN_TREE resolved from parent scopes 0 Identifier bar EXPRESSION resolve result test_us7va76b.test.bar place JOIN_TREE resolved from parent scopes 0 Expression argument name to node 0 Alias name to expression node table size 0 Alias name to function node table size 0 Alias name to table expression node table size 0 CTE name to query node table size 0 WINDOW name to window node table size 0 Nodes with duplicated aliases size 0 Expression resolve process stack 1 Expression COLUMNS(bar, foo, xyz) APPLY length Table expressions in resolve process size 0 Non cached identifier lookups during expression resolve 0 Table expression node to data 1 Table expression node test_us7va76b.test data Table expression name test_us7va76b.test table expression description table database name test_us7va76b table name test should qualify columns 1 columns size 12 Column name _block_offset column node COLUMN id: 0, column_name: _block_offset, result_type: UInt64, source_id: 1 Column name _block_number column node COLUMN id: 0, column_name: _block_number, result_type: UInt64, source_id: 1 Column name _part_offset column node COLUMN id: 0, column_name: _part_offset, result_type: UInt64, source_id: 1 Column name _row_exists column node COLUMN id: 0, column_name: _row_exists, result_type: UInt8, source_id: 1 Column name _partition_id column node COLUMN id: 0, column_name: _partition_id, result_type: LowCardinality(String), source_id: 1 Column name _part_uuid column node COLUMN id: 0, column_name: _part_uuid, result_type: UUID, source_id: 1 Column name _part_index column node COLUMN id: 0, column_name: _part_index, result_type: UInt64, source_id: 1 Column name _part_data_version column node COLUMN id: 0, column_name: _part_data_version, result_type: UInt64, source_id: 1 Column name _sample_factor column node COLUMN id: 0, column_name: _sample_factor, result_type: Float64, source_id: 1 Column name bar column node COLUMN id: 0, column_name: bar, result_type: String, source_id: 1 Column name _part column node COLUMN id: 0, column_name: _part, result_type: LowCardinality(String), source_id: 1 Column name foo column node COLUMN id: 0, column_name: foo, result_type: String, source_id: 1 Use identifier lookup to result cache 1 Subquery depth 0 . (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:45058) (comment: 03152_analyzer_columns_list.sql) (in query: SELECT COLUMNS(bar, foo, xyz) APPLY (length) FROM 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa0996d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1878: DB::QueryAnalyzer::resolveUnqualifiedMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334c87b5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334cabc4 6. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344f323 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 9. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 27. ? @ 0x00007f100c857ac3 28. ? @ 0x00007f100c8e9850 2025.10.23 23:41:46.877701 [ 2903 ] {ddf17973-8b2d-48a5-aa05-561368d5d996} TCPHandler: Code: 47. DB::Exception: Unknown identifier 'xyz' inside COLUMNS matcher. In scope Scope node SELECT COLUMNS(bar, foo, xyz) APPLY length FROM test Identifier lookup to resolve state 2 Identifier foo EXPRESSION resolve result test_us7va76b.test.foo place JOIN_TREE resolved from parent scopes 0 Identifier bar EXPRESSION resolve result test_us7va76b.test.bar place JOIN_TREE resolved from parent scopes 0 Expression argument name to node 0 Alias name to expression node table size 0 Alias name to function node table size 0 Alias name to table expression node table size 0 CTE name to query node table size 0 WINDOW name to window node table size 0 Nodes with duplicated aliases size 0 Expression resolve process stack 1 Expression COLUMNS(bar, foo, xyz) APPLY length Table expressions in resolve process size 0 Non cached identifier lookups during expression resolve 0 Table expression node to data 1 Table expression node test_us7va76b.test data Table expression name test_us7va76b.test table expression description table database name test_us7va76b table name test should qualify columns 1 columns size 12 Column name _block_offset column node COLUMN id: 0, column_name: _block_offset, result_type: UInt64, source_id: 1 Column name _block_number column node COLUMN id: 0, column_name: _block_number, result_type: UInt64, source_id: 1 Column name _part_offset column node COLUMN id: 0, column_name: _part_offset, result_type: UInt64, source_id: 1 Column name _row_exists column node COLUMN id: 0, column_name: _row_exists, result_type: UInt8, source_id: 1 Column name _partition_id column node COLUMN id: 0, column_name: _partition_id, result_type: LowCardinality(String), source_id: 1 Column name _part_uuid column node COLUMN id: 0, column_name: _part_uuid, result_type: UUID, source_id: 1 Column name _part_index column node COLUMN id: 0, column_name: _part_index, result_type: UInt64, source_id: 1 Column name _part_data_version column node COLUMN id: 0, column_name: _part_data_version, result_type: UInt64, source_id: 1 Column name _sample_factor column node COLUMN id: 0, column_name: _sample_factor, result_type: Float64, source_id: 1 Column name bar column node COLUMN id: 0, column_name: bar, result_type: String, source_id: 1 Column name _part column node COLUMN id: 0, column_name: _part, result_type: LowCardinality(String), source_id: 1 Column name foo column node COLUMN id: 0, column_name: foo, result_type: String, source_id: 1 Use identifier lookup to result cache 1 Subquery depth 0 . (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa0996d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1878: DB::QueryAnalyzer::resolveUnqualifiedMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334c87b5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334cabc4 6. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344f323 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 9. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 27. ? @ 0x00007f100c857ac3 28. ? @ 0x00007f100c8e9850 2025.10.23 23:41:46.933752 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:46.989191 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:47.392319 [ 3426 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:47.490022 [ 3060 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:47.534006 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:47.606864 [ 7652 ] {48f06193-cb49-44ff-8a8a-b98124c31b31} executeQuery: Code: 57. DB::Exception: Table test_11.test already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03039_dynamic_collapsing_merge_tree.sh) (in query: /* ddl_entry=query-0000000079 */ CREATE TABLE test_11.test UUID '18cfd3aa-24a4-42a7-a3b4-fd2a40f91bca' (`id` UInt64, `sign` Int8, `d` Dynamic) ENGINE = CollapsingMergeTree(sign) ORDER BY id SETTINGS min_rows_for_wide_part = 100000000000, min_bytes_for_wide_part = 1000000000000, index_granularity = 8128, ratio_of_defaults_for_sparse_serialization = 0.6143043637275696, replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 147519838, compact_parts_max_bytes_to_buffer = 122581827, compact_parts_max_granules_to_buffer = 156, compact_parts_merge_max_bytes_to_prefetch_part = 22349498, merge_max_block_size = 8128, old_parts_lifetime = 92., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10040125060, index_granularity_bytes = 10485760, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90103, primary_key_compress_block_size = 42526), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003395fc9e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000033958fac 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ad726d 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a52a3c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfab2 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:41:47.773200 [ 7652 ] {48f06193-cb49-44ff-8a8a-b98124c31b31} executeQuery: Code: 57. DB::Exception: Table test_11.test already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:50262) (comment: 03039_dynamic_collapsing_merge_tree.sh) (in query: CREATE TABLE test (`id` UInt64, `sign` Int8, `d` Dynamic) ENGINE = CollapsingMergeTree(sign) ORDER BY id SETTINGS min_rows_for_wide_part = 100000000000, min_bytes_for_wide_part = 1000000000000, index_granularity = 8128, ratio_of_defaults_for_sparse_serialization = 0.6143043637275696, replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 147519838, compact_parts_max_bytes_to_buffer = 122581827, compact_parts_max_granules_to_buffer = 156, compact_parts_merge_max_bytes_to_prefetch_part = 22349498, merge_max_block_size = 8128, old_parts_lifetime = 92., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10040125060, index_granularity_bytes = 10485760, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90103, primary_key_compress_block_size = 42526), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003395fc9e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000033958fac 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ad726d 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a52a3c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfab2 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:41:47.776003 [ 7652 ] {48f06193-cb49-44ff-8a8a-b98124c31b31} TCPHandler: Code: 57. DB::Exception: Table test_11.test already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003395fc9e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000033958fac 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ad726d 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a52a3c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfab2 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:41:48.049911 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:48.147009 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:48.393202 [ 3410 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:48.490976 [ 3136 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:48.584320 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:49.113094 [ 7652 ] {24e9916b-e3c7-4971-81c0-dfa5335e3df2} executeQuery: Code: 20. DB::Exception: Number of columns doesn't match (source: 3 and result: 2). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:50324) (comment: 03039_dynamic_collapsing_merge_tree.sh) (in query: insert into test select number, 1, number from numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b989f4d 4. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1464: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000033273bcf 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034bb0883 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034bbac4c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:41:49.117242 [ 7652 ] {24e9916b-e3c7-4971-81c0-dfa5335e3df2} TCPHandler: Code: 20. DB::Exception: Number of columns doesn't match (source: 3 and result: 2). (NUMBER_OF_COLUMNS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b989f4d 4. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1464: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000033273bcf 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034bb0883 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034bbac4c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:41:49.245088 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:49.291325 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:49.393974 [ 3444 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:49.492146 [ 3091 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:49.661129 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:49.856308 [ 7652 ] {b62ee7e1-9862-4ded-bbad-b0ccf0e3e86b} executeQuery: Code: 20. DB::Exception: Number of columns doesn't match (source: 3 and result: 2). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:50374) (comment: 03039_dynamic_collapsing_merge_tree.sh) (in query: insert into test select number, -1, 'str_' || toString(number) from numbers(50000, 100000)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b989f4d 4. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1464: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000033273bcf 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034bb0883 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034bbac4c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:41:49.858794 [ 7652 ] {b62ee7e1-9862-4ded-bbad-b0ccf0e3e86b} TCPHandler: Code: 20. DB::Exception: Number of columns doesn't match (source: 3 and result: 2). (NUMBER_OF_COLUMNS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b989f4d 4. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1464: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000033273bcf 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034bb0883 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034bbac4c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:41:50.379137 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:50.394805 [ 3284 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:50.480339 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:50.493065 [ 3299 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:50.726589 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:51.395929 [ 3144 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:51.467890 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:51.493877 [ 3157 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:51.559441 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:51.764071 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:52.396771 [ 3457 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:52.439093 [ 7652 ] {9c049f81-58da-48d5-bede-e57bcbfe468c} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'd' in scope SELECT count(), dynamicType(d) FROM test GROUP BY dynamicType(d) ORDER BY count() ASC, dynamicType(d) ASC. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:50414) (comment: 03039_dynamic_collapsing_merge_tree.sh) (in query: select count(), dynamicType(d) from test group by dynamicType(d) order by count(), dynamicType(d)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000335017e7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003345512b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349d355 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 2025.10.23 23:41:52.441394 [ 7652 ] {9c049f81-58da-48d5-bede-e57bcbfe468c} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'd' in scope SELECT count(), dynamicType(d) FROM test GROUP BY dynamicType(d) ORDER BY count() ASC, dynamicType(d) ASC. Maybe you meant: ['x']. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000335017e7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003345512b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349d355 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 2025.10.23 23:41:52.494659 [ 3143 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:52.513359 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:52.646552 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:52.807950 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:53.397481 [ 3216 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:53.495415 [ 3289 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:53.575880 [ 2904 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x00000000315a10ad 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159da2f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b6b4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa269fb 10. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:53.596308 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:53.672333 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:53.864045 [ 18541 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:53.870405 [ 9557 ] {3252abd4-fff9-49bf-bfee-facb26f3668a} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'd' in scope SELECT count(), dynamicType(d) FROM test GROUP BY dynamicType(d) ORDER BY count() ASC, dynamicType(d) ASC. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:50570) (comment: 03039_dynamic_collapsing_merge_tree.sh) (in query: select count(), dynamicType(d) from test group by dynamicType(d) order by count(), dynamicType(d)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000335017e7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003345512b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349d355 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 2025.10.23 23:41:53.936514 [ 9557 ] {3252abd4-fff9-49bf-bfee-facb26f3668a} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'd' in scope SELECT count(), dynamicType(d) FROM test GROUP BY dynamicType(d) ORDER BY count() ASC, dynamicType(d) ASC. Maybe you meant: ['x']. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000335017e7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003345512b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349d355 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 2025.10.23 23:41:54.398386 [ 3308 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:54.496424 [ 3226 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:54.664121 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:54.795962 [ 18541 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:55.022461 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:55.399308 [ 3095 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:55.497483 [ 3073 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:55.753162 [ 18541 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:55.863315 [ 2904 ] {c368d112-edc8-437f-b35a-15d1561add9b} executeQuery: Code: 57. DB::Exception: Table test_11.test already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03039_dynamic_collapsing_merge_tree.sh) (in query: /* ddl_entry=query-0000000081 */ CREATE TABLE test_11.test UUID 'd858f5b7-be35-43db-bfff-969abfacfb41' (`id` UInt64, `sign` Int8, `d` Dynamic) ENGINE = CollapsingMergeTree(sign) ORDER BY id SETTINGS min_rows_for_wide_part = 1, min_bytes_for_wide_part = 1, index_granularity = 8128, ratio_of_defaults_for_sparse_serialization = 0.6143043637275696, replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 147519838, compact_parts_max_bytes_to_buffer = 122581827, compact_parts_max_granules_to_buffer = 156, compact_parts_merge_max_bytes_to_prefetch_part = 22349498, merge_max_block_size = 8128, old_parts_lifetime = 92., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10040125060, index_granularity_bytes = 10485760, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90103, primary_key_compress_block_size = 42526), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003395fc9e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000033958fac 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ad726d 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a52a3c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfab2 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:41:55.873077 [ 2904 ] {c368d112-edc8-437f-b35a-15d1561add9b} executeQuery: Code: 57. DB::Exception: Table test_11.test already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:35544) (comment: 03039_dynamic_collapsing_merge_tree.sh) (in query: CREATE TABLE test (`id` UInt64, `sign` Int8, `d` Dynamic) ENGINE = CollapsingMergeTree(sign) ORDER BY id SETTINGS min_rows_for_wide_part = 1, min_bytes_for_wide_part = 1, index_granularity = 8128, ratio_of_defaults_for_sparse_serialization = 0.6143043637275696, replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 147519838, compact_parts_max_bytes_to_buffer = 122581827, compact_parts_max_granules_to_buffer = 156, compact_parts_merge_max_bytes_to_prefetch_part = 22349498, merge_max_block_size = 8128, old_parts_lifetime = 92., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10040125060, index_granularity_bytes = 10485760, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90103, primary_key_compress_block_size = 42526), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003395fc9e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000033958fac 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ad726d 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a52a3c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfab2 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:41:55.905513 [ 18541 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:55.875648 [ 2904 ] {c368d112-edc8-437f-b35a-15d1561add9b} TCPHandler: Code: 57. DB::Exception: Table test_11.test already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003395fc9e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000033958fac 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ad726d 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a52a3c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfab2 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:41:56.205101 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:56.400124 [ 3321 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:56.498293 [ 3306 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:56.856194 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:56.984666 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:57.234413 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:57.332351 [ 9557 ] {d273e463-4f58-46ce-9bda-0034783e0c67} executeQuery: Code: 20. DB::Exception: Number of columns doesn't match (source: 3 and result: 2). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:35614) (comment: 03039_dynamic_collapsing_merge_tree.sh) (in query: insert into test select number, 1, number from numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b989f4d 4. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1464: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000033273bcf 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034bb0883 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034bbac4c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:41:57.335624 [ 9557 ] {d273e463-4f58-46ce-9bda-0034783e0c67} TCPHandler: Code: 20. DB::Exception: Number of columns doesn't match (source: 3 and result: 2). (NUMBER_OF_COLUMNS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b989f4d 4. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1464: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000033273bcf 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034bb0883 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034bbac4c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:41:57.401103 [ 3493 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:57.499205 [ 3397 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:57.952287 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:58.086377 [ 18541 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:58.115510 [ 9557 ] {5400fb3f-cd60-4689-9f98-b08629944490} executeQuery: Code: 20. DB::Exception: Number of columns doesn't match (source: 3 and result: 2). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:35662) (comment: 03039_dynamic_collapsing_merge_tree.sh) (in query: insert into test select number, -1, 'str_' || toString(number) from numbers(50000, 100000)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b989f4d 4. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1464: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000033273bcf 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034bb0883 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034bbac4c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:41:58.118195 [ 9557 ] {5400fb3f-cd60-4689-9f98-b08629944490} TCPHandler: Code: 20. DB::Exception: Number of columns doesn't match (source: 3 and result: 2). (NUMBER_OF_COLUMNS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b989f4d 4. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1464: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000033273bcf 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034bb0883 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034bbac4c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:41:58.388288 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:58.401973 [ 3539 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:58.500257 [ 3287 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:58.910069 [ 2904 ] {94320f10-7bd8-4987-9061-dab70e93d87a} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'd' in scope SELECT count(), dynamicType(d) FROM test GROUP BY dynamicType(d) ORDER BY count() ASC, dynamicType(d) ASC. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:35698) (comment: 03039_dynamic_collapsing_merge_tree.sh) (in query: select count(), dynamicType(d) from test group by dynamicType(d) order by count(), dynamicType(d)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000335017e7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003345512b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349d355 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 2025.10.23 23:41:58.913050 [ 2904 ] {94320f10-7bd8-4987-9061-dab70e93d87a} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'd' in scope SELECT count(), dynamicType(d) FROM test GROUP BY dynamicType(d) ORDER BY count() ASC, dynamicType(d) ASC. Maybe you meant: ['x']. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000335017e7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003345512b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349d355 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 2025.10.23 23:41:59.069780 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:59.170623 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:59.402670 [ 3264 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:59.469108 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:41:59.501000 [ 3364 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:00.159436 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:00.208044 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:00.403578 [ 3099 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:00.435015 [ 18541 ] {13cc4bca-94ba-467e-a5a6-7021086db5d0} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'd' in scope SELECT count(), dynamicType(d) FROM test GROUP BY dynamicType(d) ORDER BY count() ASC, dynamicType(d) ASC. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:35746) (comment: 03039_dynamic_collapsing_merge_tree.sh) (in query: select count(), dynamicType(d) from test group by dynamicType(d) order by count(), dynamicType(d)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000335017e7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003345512b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349d355 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 2025.10.23 23:42:00.439021 [ 18541 ] {13cc4bca-94ba-467e-a5a6-7021086db5d0} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'd' in scope SELECT count(), dynamicType(d) FROM test GROUP BY dynamicType(d) ORDER BY count() ASC, dynamicType(d) ASC. Maybe you meant: ['x']. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000335017e7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003345512b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349d355 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 2025.10.23 23:42:00.502174 [ 3075 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:00.516449 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:01.214244 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:01.273867 [ 18542 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:01.288294 [ 3169 ] {} test_3.table1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.10.23 23:42:01.288477 [ 3288 ] {} test_3.rmt (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.10.23 23:42:01.288643 [ 3415 ] {} test_15.r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.10.23 23:42:01.289125 [ 3478 ] {} test_3.`02691_drop_column_replicated` (1045b1a8-f37f-4f75-892a-b44e770b298b): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_3/test/02691_drop_column/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:01.289227 [ 3283 ] {} test_3.rmt (1c58b3d3-3aa3-4fc2-81b4-6ea1ac046ae6): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/02253/02253_empty_part_checksums_test_3/rmt/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:01.289468 [ 3423 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000003cc8de51 3. ./src/Common/ZooKeeper/IKeeper.h:509: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003cd16a3e 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1383: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x000000003cd1a472 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x000000003cbf5306 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:610: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x000000003cbf42db 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000003cbf676b 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003cbf5ab3 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x000000003a0eb80c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889e7df 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:01.289565 [ 3560 ] {} test_3.`02691_drop_column_replicated` (1045b1a8-f37f-4f75-892a-b44e770b298b): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000003cc8de51 3. ./src/Common/ZooKeeper/IKeeper.h:509: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003cd16a3e 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003cd2369f 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe6e6d 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe5f26 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe84e7 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe81ea 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000003a10064e 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000003889f11d 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f9f 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:01.289688 [ 3058 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000003cc8de51 3. ./src/Common/ZooKeeper/IKeeper.h:509: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003cd16a3e 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003cd2369f 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe6e6d 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe5f26 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe84e7 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe81ea 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000003a10064e 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000003889f11d 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f9f 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:01.291267 [ 3214 ] {} test_3.rmt (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Session expired (fault injected on send). (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000003a21d8b1 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEES0_NS_5ErrorEOS5_ @ 0x000000003cd2cd64 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1654: Coordination::ZooKeeper::maybeInjectSendFault() @ 0x000000003cd17122 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003cd165e8 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000003cd20792 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryExistsNoThrow(String const&, std::function) @ 0x000000003cbf3581 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003cbf26a1 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000003cbf3a70 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003cbea871 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000003a0439c9 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a04133c 13. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:50: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a03dd98 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003a06697f 15. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 17. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:01.404833 [ 3251 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:01.503233 [ 3054 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:01.597687 [ 18541 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:01.998542 [ 22118 ] {85ebc9d3-f450-4c3b-848e-ec226b9cf540} virtual void DB::StorageBuffer::flushAndPrepareForShutdown(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=5). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/StorageBuffer.cpp:0: DB::StorageBuffer::flushAllBuffers(bool) @ 0x0000000038ddb12c 8. ./build_docker/./src/Storages/StorageBuffer.cpp:0: DB::StorageBuffer::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x0000000038dda6c8 9. ./contrib/llvm-project/libcxx/include/vector:438: DB::StorageBuffer::flushAndPrepareForShutdown() @ 0x0000000038dd9ed3 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003494db3e 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000303f120c 12. ./contrib/llvm-project/libcxx/include/future:1694: std::__packaged_task_func>, std::function>::operator()(std::function&&, Priority)::'lambda'(), std::allocator>, std::function>::operator()(std::function&&, Priority)::'lambda'()>, void ()>::operator()() @ 0x00000000303f0fed 13. ./contrib/llvm-project/libcxx/include/future:2069: std::packaged_task::operator()() @ 0x00000000214b57dd 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000303f36ee 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 16. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:02.247964 [ 18542 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:02.289985 [ 3356 ] {} test_3.`02691_drop_column_replicated` (1045b1a8-f37f-4f75-892a-b44e770b298b): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_3/test/02691_drop_column/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:02.343455 [ 18542 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:02.392784 [ 18541 ] {87e8d2a8-633e-46a3-bad0-56435527f204} executeQuery: Code: 57. DB::Exception: Table test_11.test already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03039_dynamic_collapsing_merge_tree.sh) (in query: /* ddl_entry=query-0000000082 */ CREATE TABLE test_11.test UUID 'e9651aa8-eba9-4f9b-b434-a26ef14f9bc0' (`id` UInt64, `sign` Int8, `d` Dynamic) ENGINE = CollapsingMergeTree(sign) ORDER BY id SETTINGS min_rows_for_wide_part = 100000000000, min_bytes_for_wide_part = 1000000000000, 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 = 0.6143043637275696, replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 147519838, compact_parts_max_bytes_to_buffer = 122581827, compact_parts_max_granules_to_buffer = 156, compact_parts_merge_max_bytes_to_prefetch_part = 22349498, merge_max_block_size = 8128, old_parts_lifetime = 92., prefer_fetch_merged_part_size_threshold = 1, min_merge_bytes_to_use_direct_io = 10040125060, index_granularity_bytes = 10485760, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90103, primary_key_compress_block_size = 42526), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003395fc9e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000033958fac 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ad726d 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a52a3c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfab2 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:42:02.399540 [ 18541 ] {87e8d2a8-633e-46a3-bad0-56435527f204} executeQuery: Code: 57. DB::Exception: Table test_11.test already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:35804) (comment: 03039_dynamic_collapsing_merge_tree.sh) (in query: CREATE TABLE test (`id` UInt64, `sign` Int8, `d` Dynamic) ENGINE = CollapsingMergeTree(sign) ORDER BY id SETTINGS min_rows_for_wide_part = 100000000000, min_bytes_for_wide_part = 1000000000000, 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 = 0.6143043637275696, replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 147519838, compact_parts_max_bytes_to_buffer = 122581827, compact_parts_max_granules_to_buffer = 156, compact_parts_merge_max_bytes_to_prefetch_part = 22349498, merge_max_block_size = 8128, old_parts_lifetime = 92., prefer_fetch_merged_part_size_threshold = 1, min_merge_bytes_to_use_direct_io = 10040125060, index_granularity_bytes = 10485760, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90103, primary_key_compress_block_size = 42526), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003395fc9e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000033958fac 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ad726d 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a52a3c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfab2 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:42:02.402379 [ 18541 ] {87e8d2a8-633e-46a3-bad0-56435527f204} TCPHandler: Code: 57. DB::Exception: Table test_11.test already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003395fc9e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000033958fac 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ad726d 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a52a3c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfab2 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:42:02.405646 [ 3511 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:02.504121 [ 3565 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:02.668537 [ 18541 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:03.183482 [ 9557 ] {85ebc9d3-f450-4c3b-848e-ec226b9cf540} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=3). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:35750) (comment: 01160_table_dependencies.sh) (in query: detach database test_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000003494763c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:42:03.187381 [ 9557 ] {85ebc9d3-f450-4c3b-848e-ec226b9cf540} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000003494763c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:42:03.291148 [ 3373 ] {} test_3.`02691_drop_column_replicated` (1045b1a8-f37f-4f75-892a-b44e770b298b): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_3/test/02691_drop_column/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:03.308985 [ 18541 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:03.406347 [ 3345 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:03.417702 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:03.504899 [ 3135 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:03.593896 [ 9557 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x00000000315a10ad 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159da2f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b6b4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa269fb 10. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:03.718635 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:03.821749 [ 18541 ] {325a54bb-1b1f-4faa-bf88-c64f615bfeee} executeQuery: Code: 20. DB::Exception: Number of columns doesn't match (source: 3 and result: 2). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:35856) (comment: 03039_dynamic_collapsing_merge_tree.sh) (in query: insert into test select number, 1, number from numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b989f4d 4. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1464: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000033273bcf 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034bb0883 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034bbac4c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:42:03.824054 [ 18541 ] {325a54bb-1b1f-4faa-bf88-c64f615bfeee} TCPHandler: Code: 20. DB::Exception: Number of columns doesn't match (source: 3 and result: 2). (NUMBER_OF_COLUMNS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b989f4d 4. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1464: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000033273bcf 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034bb0883 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034bbac4c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:42:04.292316 [ 3289 ] {} test_3.`02691_drop_column_replicated` (1045b1a8-f37f-4f75-892a-b44e770b298b): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_3/test/02691_drop_column/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:04.395140 [ 18541 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:04.406947 [ 3444 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:04.505813 [ 3508 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:04.578322 [ 18542 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:04.579314 [ 18541 ] {a2fa56b8-2b40-4a69-9935-d892badedf93} executeQuery: Code: 20. DB::Exception: Number of columns doesn't match (source: 3 and result: 2). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:35876) (comment: 03039_dynamic_collapsing_merge_tree.sh) (in query: insert into test select number, -1, 'str_' || toString(number) from numbers(50000, 100000)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b989f4d 4. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1464: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000033273bcf 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034bb0883 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034bbac4c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:42:04.582006 [ 18541 ] {a2fa56b8-2b40-4a69-9935-d892badedf93} TCPHandler: Code: 20. DB::Exception: Number of columns doesn't match (source: 3 and result: 2). (NUMBER_OF_COLUMNS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b989f4d 4. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1464: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000033273bcf 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034bb0883 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034bbac4c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:42:04.745825 [ 18542 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:04.777713 [ 3113 ] {} test_3.`02691_drop_column_replicated` (1045b1a8-f37f-4f75-892a-b44e770b298b): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_3/test/02691_drop_column/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:05.096579 [ 9557 ] {c2cb4d6d-1a9a-4ac7-8f0c-760992ccb7e1} executeQuery: Code: 82. DB::Exception: Database test_3 already exists. (DATABASE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:35862) (comment: 01160_table_dependencies.sh) (in query: attach database test_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000842350a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:147: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000348979e7 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 2025.10.23 23:42:05.098878 [ 9557 ] {c2cb4d6d-1a9a-4ac7-8f0c-760992ccb7e1} TCPHandler: Code: 82. DB::Exception: Database test_3 already exists. (DATABASE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000842350a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:147: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000348979e7 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 2025.10.23 23:42:05.293180 [ 3180 ] {} test_3.`02691_drop_column_replicated` (1045b1a8-f37f-4f75-892a-b44e770b298b): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_3/test/02691_drop_column/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:05.335488 [ 9557 ] {cc594842-5260-447b-bfa1-d5732f7332ba} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'd' in scope SELECT count(), dynamicType(d) FROM test GROUP BY dynamicType(d) ORDER BY count() ASC, dynamicType(d) ASC. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:33504) (comment: 03039_dynamic_collapsing_merge_tree.sh) (in query: select count(), dynamicType(d) from test group by dynamicType(d) order by count(), dynamicType(d)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000335017e7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003345512b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349d355 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 2025.10.23 23:42:05.338571 [ 9557 ] {cc594842-5260-447b-bfa1-d5732f7332ba} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'd' in scope SELECT count(), dynamicType(d) FROM test GROUP BY dynamicType(d) ORDER BY count() ASC, dynamicType(d) ASC. Maybe you meant: ['x']. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000335017e7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003345512b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349d355 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 2025.10.23 23:42:05.408110 [ 3479 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:05.484627 [ 18541 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:05.506857 [ 3075 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:05.637097 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:05.778459 [ 3284 ] {} test_3.`02691_drop_column_replicated` (1045b1a8-f37f-4f75-892a-b44e770b298b): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_3/test/02691_drop_column/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:05.892843 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:06.335202 [ 3448 ] {} test_3.`02691_drop_column_replicated` (1045b1a8-f37f-4f75-892a-b44e770b298b): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_3/test/02691_drop_column/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:06.335301 [ 3346 ] {} test_3.table1 (b8db3d6a-6199-4d9d-9ab7-f9a99f2d7089): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_3/test_table12/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:06.335332 [ 3522 ] {} test_3.rmt (1c58b3d3-3aa3-4fc2-81b4-6ea1ac046ae6): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/02253/02253_empty_part_checksums_test_3/rmt/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:06.409048 [ 3294 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:06.507610 [ 3108 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:06.584938 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:06.779323 [ 3530 ] {} test_3.`02691_drop_column_replicated` (1045b1a8-f37f-4f75-892a-b44e770b298b): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_3/test/02691_drop_column/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:06.827399 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:06.828944 [ 18542 ] {b2eff818-aed2-490d-88ec-c054437fbbdc} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'd' in scope SELECT count(), dynamicType(d) FROM test GROUP BY dynamicType(d) ORDER BY count() ASC, dynamicType(d) ASC. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:33602) (comment: 03039_dynamic_collapsing_merge_tree.sh) (in query: select count(), dynamicType(d) from test group by dynamicType(d) order by count(), dynamicType(d)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000335017e7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003345512b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349d355 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 2025.10.23 23:42:06.831343 [ 18542 ] {b2eff818-aed2-490d-88ec-c054437fbbdc} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'd' in scope SELECT count(), dynamicType(d) FROM test GROUP BY dynamicType(d) ORDER BY count() ASC, dynamicType(d) ASC. Maybe you meant: ['x']. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000335017e7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003345512b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349d355 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 2025.10.23 23:42:06.954280 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:06.959391 [ 9764 ] {8d9951ba-c2b2-45e1-ae53-1468e7be5b02} virtual void DB::StorageBuffer::flushAndPrepareForShutdown(): 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/StorageBuffer.cpp:0: DB::StorageBuffer::flushAllBuffers(bool) @ 0x0000000038ddb12c 8. ./build_docker/./src/Storages/StorageBuffer.cpp:0: DB::StorageBuffer::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x0000000038dda6c8 9. ./contrib/llvm-project/libcxx/include/vector:438: DB::StorageBuffer::flushAndPrepareForShutdown() @ 0x0000000038dd9ed3 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003494db3e 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000303f120c 12. ./contrib/llvm-project/libcxx/include/future:1694: std::__packaged_task_func>, std::function>::operator()(std::function&&, Priority)::'lambda'(), std::allocator>, std::function>::operator()(std::function&&, Priority)::'lambda'()>, void ()>::operator()() @ 0x00000000303f0fed 13. ./contrib/llvm-project/libcxx/include/future:2069: std::packaged_task::operator()() @ 0x00000000214b57dd 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000303f36ee 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 16. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:07.336466 [ 3163 ] {} test_3.table1 (b8db3d6a-6199-4d9d-9ab7-f9a99f2d7089): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_3/test_table12/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:07.336650 [ 3336 ] {} test_3.rmt (1c58b3d3-3aa3-4fc2-81b4-6ea1ac046ae6): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/02253/02253_empty_part_checksums_test_3/rmt/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:07.409993 [ 3549 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:07.508580 [ 3560 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:07.681907 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:07.890690 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:08.070799 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:08.337449 [ 3146 ] {} test_3.table1 (b8db3d6a-6199-4d9d-9ab7-f9a99f2d7089): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_3/test_table12/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:08.337583 [ 3515 ] {} test_3.rmt (1c58b3d3-3aa3-4fc2-81b4-6ea1ac046ae6): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/02253/02253_empty_part_checksums_test_3/rmt/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:08.340368 [ 18542 ] {0cb3a0f3-2537-443d-9ae9-f1f6a707c2da} executeQuery: Code: 57. DB::Exception: Table test_11.test already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03039_dynamic_collapsing_merge_tree.sh) (in query: /* ddl_entry=query-0000000083 */ CREATE TABLE test_11.test UUID 'c83d8e0d-dcd2-44b1-b961-e78d692bd85c' (`id` UInt64, `sign` Int8, `d` Dynamic) ENGINE = CollapsingMergeTree(sign) 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 = 0.6143043637275696, replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 147519838, compact_parts_max_bytes_to_buffer = 122581827, compact_parts_max_granules_to_buffer = 156, compact_parts_merge_max_bytes_to_prefetch_part = 22349498, merge_max_block_size = 8128, old_parts_lifetime = 92., prefer_fetch_merged_part_size_threshold = 1, min_merge_bytes_to_use_direct_io = 10040125060, index_granularity_bytes = 10485760, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90103, primary_key_compress_block_size = 42526), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003395fc9e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000033958fac 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ad726d 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a52a3c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfab2 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:42:08.349474 [ 18542 ] {0cb3a0f3-2537-443d-9ae9-f1f6a707c2da} executeQuery: Code: 57. DB::Exception: Table test_11.test already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:33672) (comment: 03039_dynamic_collapsing_merge_tree.sh) (in query: CREATE TABLE test (`id` UInt64, `sign` Int8, `d` Dynamic) ENGINE = CollapsingMergeTree(sign) 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 = 0.6143043637275696, replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 147519838, compact_parts_max_bytes_to_buffer = 122581827, compact_parts_max_granules_to_buffer = 156, compact_parts_merge_max_bytes_to_prefetch_part = 22349498, merge_max_block_size = 8128, old_parts_lifetime = 92., prefer_fetch_merged_part_size_threshold = 1, min_merge_bytes_to_use_direct_io = 10040125060, index_granularity_bytes = 10485760, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90103, primary_key_compress_block_size = 42526), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003395fc9e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000033958fac 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ad726d 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a52a3c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfab2 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:42:08.352235 [ 18542 ] {0cb3a0f3-2537-443d-9ae9-f1f6a707c2da} TCPHandler: Code: 57. DB::Exception: Table test_11.test already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003395fc9e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000033958fac 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ad726d 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a52a3c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfab2 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:42:08.410890 [ 3162 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:08.568621 [ 3384 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:08.758214 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:09.019382 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:09.197460 [ 18542 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:09.338401 [ 3431 ] {} test_3.table1 (b8db3d6a-6199-4d9d-9ab7-f9a99f2d7089): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_3/test_table12/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:09.338464 [ 3426 ] {} test_3.rmt (1c58b3d3-3aa3-4fc2-81b4-6ea1ac046ae6): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/02253/02253_empty_part_checksums_test_3/rmt/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:09.417899 [ 3260 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:09.569723 [ 3560 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:09.766024 [ 18541 ] {8d9951ba-c2b2-45e1-ae53-1468e7be5b02} virtual void DB::StorageBuffer::flushAndPrepareForShutdown(): 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/StorageBuffer.cpp:0: DB::StorageBuffer::flushAllBuffers(bool) @ 0x0000000038ddb12c 8. ./build_docker/./src/Storages/StorageBuffer.cpp:0: DB::StorageBuffer::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x0000000038dda6c8 9. ./contrib/llvm-project/libcxx/include/vector:438: DB::StorageBuffer::flushAndPrepareForShutdown() @ 0x0000000038dd9ed3 10. ./src/Storages/IStorage.h:594: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003493dc78 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:454: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034947b8d 12. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 13. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 14. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:09.856841 [ 18542 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:09.905115 [ 3652 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {d60c8165-1f8c-4cd1-8084-8b8c63363ea3::202510_83_93_2}: 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 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) @ 0x0000000039c89948 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000003999bfb7 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 @ 0x00000000399942f0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000039d15c04 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&) @ 0x0000000039d20399 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) @ 0x0000000039d1c606 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000396308a4 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x00000000396235dd 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000003963b3e0 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x00000000396504a0 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3c455d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:09.970776 [ 9557 ] {6118b683-0dda-4b02-82f0-2e2b4bdcd8f0} executeQuery: Code: 20. DB::Exception: Number of columns doesn't match (source: 3 and result: 2). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:33714) (comment: 03039_dynamic_collapsing_merge_tree.sh) (in query: insert into test select number, 1, number from numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b989f4d 4. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1464: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000033273bcf 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034bb0883 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034bbac4c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:42:09.973291 [ 9557 ] {6118b683-0dda-4b02-82f0-2e2b4bdcd8f0} TCPHandler: Code: 20. DB::Exception: Number of columns doesn't match (source: 3 and result: 2). (NUMBER_OF_COLUMNS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b989f4d 4. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1464: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000033273bcf 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034bb0883 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034bbac4c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:42:10.074963 [ 18541 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:10.299615 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:10.418664 [ 3468 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:10.570512 [ 3104 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:10.717044 [ 9557 ] {461bd0f6-ac1d-4653-a23a-a7879b030d0e} TablesLoader: Tables test_3.dist_01247 depend on default.number, but seems like that does not exist. Will ignore it and try to load existing tables 2025.10.23 23:42:10.840988 [ 18541 ] {f94b9c86-6a1a-42e0-a7f6-bbb3ae6fa503} executeQuery: Code: 20. DB::Exception: Number of columns doesn't match (source: 3 and result: 2). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:33766) (comment: 03039_dynamic_collapsing_merge_tree.sh) (in query: insert into test select number, -1, 'str_' || toString(number) from numbers(50000, 100000)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b989f4d 4. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1464: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000033273bcf 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034bb0883 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034bbac4c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:42:10.844366 [ 18541 ] {f94b9c86-6a1a-42e0-a7f6-bbb3ae6fa503} TCPHandler: Code: 20. DB::Exception: Number of columns doesn't match (source: 3 and result: 2). (NUMBER_OF_COLUMNS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b989f4d 4. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1464: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000033273bcf 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034bb0883 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034bbac4c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:42:10.917593 [ 18542 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:11.138592 [ 18541 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:11.332106 [ 18541 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:11.419445 [ 3344 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:11.571418 [ 3123 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:11.629649 [ 18541 ] {33d20020-aa23-4e29-95ec-41c9088e59fe} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'd' in scope SELECT count(), dynamicType(d) FROM test GROUP BY dynamicType(d) ORDER BY count() ASC, dynamicType(d) ASC. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:33806) (comment: 03039_dynamic_collapsing_merge_tree.sh) (in query: select count(), dynamicType(d) from test group by dynamicType(d) order by count(), dynamicType(d)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000335017e7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003345512b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349d355 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 2025.10.23 23:42:11.634002 [ 18541 ] {33d20020-aa23-4e29-95ec-41c9088e59fe} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'd' in scope SELECT count(), dynamicType(d) FROM test GROUP BY dynamicType(d) ORDER BY count() ASC, dynamicType(d) ASC. Maybe you meant: ['x']. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000335017e7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003345512b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349d355 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 2025.10.23 23:42:11.954614 [ 22133 ] {} void DB::AsyncLoader::worker(Pool &): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=9, jobs=9): Cannot attach table `test_3`.`hypothesis_test_test2` from metadata file /var/lib/clickhouse/store/72e/72e8cccc-d01c-48de-9c15-1f652f3a0118/hypothesis_test_test2.sql from query ATTACH TABLE test_3.hypothesis_test_test2 UUID '5477f859-0503-4b73-8c63-4552642ae0f9' (`i` UInt64, `a` UInt64, `b` UInt64, INDEX t a != b TYPE hypothesis GRANULARITY 1) ENGINE = MergeTree ORDER BY i SETTINGS index_granularity = 1, min_bytes_for_wide_part = 541106134, ratio_of_defaults_for_sparse_serialization = 0.8795791864395142, replace_long_file_name_to_hash = false, max_file_name_length = 37, min_bytes_for_full_part_storage = 34031348, compact_parts_max_bytes_to_buffer = 329230274, compact_parts_max_granules_to_buffer = 104, compact_parts_merge_max_bytes_to_prefetch_part = 6975552, merge_max_block_size = 11477, 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 = 3, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 2773336, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 99972, primary_key_compress_block_size = 31029. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x0000000039709f85 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>) @ 0x000000003a2e5f4a 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a2e404f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2d3063 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7b27a 12. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x0000000038308626 13. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:0: DB::createTableFromAST(DB::ASTCreateQuery, String const&, String const&, std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000003294a31d 14. ./contrib/llvm-project/libcxx/include/string:1499: DB::DatabaseOrdinary::loadTableFromMetadata(std::shared_ptr, String const&, DB::QualifiedTableName const&, std::shared_ptr const&, DB::LoadingStrictnessLevel) @ 0x00000000329c9071 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000329e2adb 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000207110e6 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000020712b00 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 21. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:11.981310 [ 18541 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:12.030129 [ 4164 ] {} void DB::AsyncLoader::worker(Pool &): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=3): Cannot attach table `test_3`.`test_03093` from metadata file /var/lib/clickhouse/store/72e/72e8cccc-d01c-48de-9c15-1f652f3a0118/test_03093.sql from query ATTACH TABLE test_3.test_03093 UUID '95768730-c59c-45c3-9b66-fd403c963743' (`app` String, `c` UInt64, `k` Map(String, String)) ENGINE = MergeTree ORDER BY app SETTINGS index_granularity = 20231, min_bytes_for_wide_part = 319694417, ratio_of_defaults_for_sparse_serialization = 0.9866463541984558, 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 = 217098242, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 23838530, merge_max_block_size = 13304, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 775558147, index_granularity_bytes = 12864408, concurrent_part_removal_threshold = 43, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 25632, primary_key_compress_block_size = 55721. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x0000000039709f85 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>) @ 0x000000003a2e5f4a 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a2e404f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2d3063 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7b27a 12. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x0000000038308626 13. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:0: DB::createTableFromAST(DB::ASTCreateQuery, String const&, String const&, std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000003294a31d 14. ./contrib/llvm-project/libcxx/include/string:1499: DB::DatabaseOrdinary::loadTableFromMetadata(std::shared_ptr, String const&, DB::QualifiedTableName const&, std::shared_ptr const&, DB::LoadingStrictnessLevel) @ 0x00000000329c9071 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000329e2adb 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000207110e6 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000020712b00 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 21. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:12.236862 [ 18541 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:12.356313 [ 22129 ] {} void DB::AsyncLoader::worker(Pool &): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1): Cannot attach table `test_3`.`test_table_01080` from metadata file /var/lib/clickhouse/store/72e/72e8cccc-d01c-48de-9c15-1f652f3a0118/test_table_01080.sql from query ATTACH TABLE test_3.test_table_01080 UUID '0f83b150-1090-4d15-8ede-4ebee14b41e6' (`dim_key` Int64, `dim_id` String) ENGINE = MergeTree ORDER BY dim_key SETTINGS index_granularity = 18570, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 0, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 395100053, compact_parts_max_granules_to_buffer = 51, compact_parts_merge_max_bytes_to_prefetch_part = 3504973, merge_max_block_size = 22036, old_parts_lifetime = 335., 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 = 1833290, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 91682, primary_key_compress_block_size = 40673. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataPartsFromDisk(std::vector, std::allocator>>&) @ 0x0000000039704427 8. ./contrib/llvm-project/libcxx/include/vector:1454: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x000000003970c533 9. ./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>) @ 0x000000003a2e5f4a 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a2e404f 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2d3063 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7b27a 13. ./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 @ 0x0000000038308626 14. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:0: DB::createTableFromAST(DB::ASTCreateQuery, String const&, String const&, std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000003294a31d 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::DatabaseOrdinary::loadTableFromMetadata(std::shared_ptr, String const&, DB::QualifiedTableName const&, std::shared_ptr const&, DB::LoadingStrictnessLevel) @ 0x00000000329c9071 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000329e2adb 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000207110e6 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000020712b00 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 22. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:12.404298 [ 18542 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:12.420219 [ 3242 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:12.572498 [ 3364 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:13.020170 [ 18541 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:13.081285 [ 18542 ] {10528126-a94d-4230-b70c-0714ea7d3b1b} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'd' in scope SELECT count(), dynamicType(d) FROM test GROUP BY dynamicType(d) ORDER BY count() ASC, dynamicType(d) ASC. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:33852) (comment: 03039_dynamic_collapsing_merge_tree.sh) (in query: select count(), dynamicType(d) from test group by dynamicType(d) order by count(), dynamicType(d)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000335017e7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003345512b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349d355 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 2025.10.23 23:42:13.085313 [ 18542 ] {10528126-a94d-4230-b70c-0714ea7d3b1b} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'd' in scope SELECT count(), dynamicType(d) FROM test GROUP BY dynamicType(d) ORDER BY count() ASC, dynamicType(d) ASC. Maybe you meant: ['x']. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000335017e7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003345512b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349d355 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 2025.10.23 23:42:13.310744 [ 18541 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:13.421315 [ 3089 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:13.472215 [ 18541 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:13.573597 [ 3232 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:14.080766 [ 18541 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:14.102577 [ 9557 ] {461bd0f6-ac1d-4653-a23a-a7879b030d0e} executeQuery: Code: 722. DB::Exception: Waited job failed: Code: 695. DB::Exception: Load job 'load table test_3.test_table_01080' failed: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1): Cannot attach table `test_3`.`test_table_01080` from metadata file /var/lib/clickhouse/store/72e/72e8cccc-d01c-48de-9c15-1f652f3a0118/test_table_01080.sql from query ATTACH TABLE test_3.test_table_01080 UUID '0f83b150-1090-4d15-8ede-4ebee14b41e6' (`dim_key` Int64, `dim_id` String) ENGINE = MergeTree ORDER BY dim_key SETTINGS index_granularity = 18570, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 0, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 395100053, compact_parts_max_granules_to_buffer = 51, compact_parts_merge_max_bytes_to_prefetch_part = 3504973, merge_max_block_size = 22036, old_parts_lifetime = 335., 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 = 1833290, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 91682, primary_key_compress_block_size = 40673. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataPartsFromDisk(std::vector, std::allocator>>&) @ 0x0000000039704427 8. ./contrib/llvm-project/libcxx/include/vector:1454: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x000000003970c533 9. ./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>) @ 0x000000003a2e5f4a 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a2e404f 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2d3063 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7b27a 13. ./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 @ 0x0000000038308626 14. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:0: DB::createTableFromAST(DB::ASTCreateQuery, String const&, String const&, std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000003294a31d 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::DatabaseOrdinary::loadTableFromMetadata(std::shared_ptr, String const&, DB::QualifiedTableName const&, std::shared_ptr const&, DB::LoadingStrictnessLevel) @ 0x00000000329c9071 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000329e2adb 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000207110e6 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000020712b00 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 22. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)). (ASYNC_LOAD_FAILED) (version 24.8.14.10542.altinitytest (altinity build)). (ASYNC_LOAD_WAIT_FAILED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:33750) (comment: 01160_table_dependencies.sh) (in query: attach database test_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Common/AsyncLoader.cpp:444: DB::AsyncLoader::wait(std::shared_ptr const&, bool) @ 0x0000000020706a5b 5. ./src/Common/AsyncLoader.h:547: DB::waitLoad(unsigned long, std::vector, std::allocator>> const&, bool) @ 0x000000002065a61b 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:369: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000348954b3 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:42:14.105515 [ 9557 ] {461bd0f6-ac1d-4653-a23a-a7879b030d0e} TCPHandler: Code: 722. DB::Exception: Waited job failed: Code: 695. DB::Exception: Load job 'load table test_3.test_table_01080' failed: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1): Cannot attach table `test_3`.`test_table_01080` from metadata file /var/lib/clickhouse/store/72e/72e8cccc-d01c-48de-9c15-1f652f3a0118/test_table_01080.sql from query ATTACH TABLE test_3.test_table_01080 UUID '0f83b150-1090-4d15-8ede-4ebee14b41e6' (`dim_key` Int64, `dim_id` String) ENGINE = MergeTree ORDER BY dim_key SETTINGS index_granularity = 18570, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 0, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 395100053, compact_parts_max_granules_to_buffer = 51, compact_parts_merge_max_bytes_to_prefetch_part = 3504973, merge_max_block_size = 22036, old_parts_lifetime = 335., 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 = 1833290, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 91682, primary_key_compress_block_size = 40673. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataPartsFromDisk(std::vector, std::allocator>>&) @ 0x0000000039704427 8. ./contrib/llvm-project/libcxx/include/vector:1454: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x000000003970c533 9. ./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>) @ 0x000000003a2e5f4a 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a2e404f 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2d3063 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7b27a 13. ./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 @ 0x0000000038308626 14. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:0: DB::createTableFromAST(DB::ASTCreateQuery, String const&, String const&, std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000003294a31d 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::DatabaseOrdinary::loadTableFromMetadata(std::shared_ptr, String const&, DB::QualifiedTableName const&, std::shared_ptr const&, DB::LoadingStrictnessLevel) @ 0x00000000329c9071 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000329e2adb 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000207110e6 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000020712b00 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 22. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)). (ASYNC_LOAD_FAILED) (version 24.8.14.10542.altinitytest (altinity build)). (ASYNC_LOAD_WAIT_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Common/AsyncLoader.cpp:444: DB::AsyncLoader::wait(std::shared_ptr const&, bool) @ 0x0000000020706a5b 5. ./src/Common/AsyncLoader.h:547: DB::waitLoad(unsigned long, std::vector, std::allocator>> const&, bool) @ 0x000000002065a61b 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:369: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000348954b3 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:42:14.375416 [ 18541 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:14.422337 [ 3147 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:14.538523 [ 18542 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:14.574799 [ 3403 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:15.126601 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:15.423082 [ 3331 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:15.450161 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:15.575027 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:15.575607 [ 3313 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:15.920949 [ 18542 ] {2c99b5d4-1571-4953-a9f1-31ad4edaa640} executeQuery: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:33916) (comment: 01160_table_dependencies.sh) (in query: detach database test_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:666: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x00000000339ae146 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000349459ff 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:15.923598 [ 18542 ] {2c99b5d4-1571-4953-a9f1-31ad4edaa640} TCPHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:666: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x00000000339ae146 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000349459ff 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:16.230069 [ 18542 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:16.423951 [ 3114 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:16.576567 [ 3531 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:16.621588 [ 18542 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:16.641129 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:17.295988 [ 18542 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:17.424637 [ 3333 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:17.577759 [ 3481 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:17.707266 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:17.715378 [ 18542 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:18.425357 [ 3113 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:18.449962 [ 18542 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:18.524257 [ 7565 ] {1d66672c-a649-4f2f-972d-685dad0f8b20} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=10, jobs=10). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:49040) (comment: 01160_table_dependencies.sh) (in query: attach database test_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202dea34 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseOnDisk::iterateMetadataFiles(std::shared_ptr, std::function const&) const @ 0x0000000032969434 7. ./build_docker/./src/Databases/DatabaseOrdinary.cpp:0: DB::DatabaseOrdinary::loadTablesMetadata(std::shared_ptr, DB::ParsedTablesMetadata&, bool) @ 0x00000000329c6c86 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:158: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000349199d0 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000348953f8 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:42:18.526677 [ 7565 ] {1d66672c-a649-4f2f-972d-685dad0f8b20} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202dea34 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseOnDisk::iterateMetadataFiles(std::shared_ptr, std::function const&) const @ 0x0000000032969434 7. ./build_docker/./src/Databases/DatabaseOrdinary.cpp:0: DB::DatabaseOrdinary::loadTablesMetadata(std::shared_ptr, DB::ParsedTablesMetadata&, bool) @ 0x00000000329c6c86 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:158: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000349199d0 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000348953f8 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:42:18.578975 [ 3133 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:18.743955 [ 18542 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:18.814628 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:19.218634 [ 18542 ] {04507b25-a327-4663-8efb-e2d161e75b8a} executeQuery: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:49090) (comment: 01160_table_dependencies.sh) (in query: detach database test_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:666: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x00000000339ae146 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000349459ff 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:19.223059 [ 18542 ] {04507b25-a327-4663-8efb-e2d161e75b8a} TCPHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:666: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x00000000339ae146 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000349459ff 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:19.426450 [ 3491 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:19.580128 [ 3170 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:19.614673 [ 18542 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:19.771380 [ 18542 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:19.879610 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:20.158689 [ 18542 ] {358bbacb-04a2-4e53-a2e9-14c3f5256ae6} TablesLoader: Tables test_3.dist_01247 depend on default.number, but seems like that does not exist. Will ignore it and try to load existing tables 2025.10.23 23:42:20.427416 [ 3199 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:20.580911 [ 3551 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:20.701591 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:20.812512 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:20.942705 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:21.428274 [ 3417 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:21.581832 [ 3206 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:21.789449 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:21.834952 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:22.019000 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:22.429136 [ 3180 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:22.534259 [ 13712 ] {} void DB::AsyncLoader::worker(Pool &): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0): Cannot attach table `test_3`.`hypothesis_test_test2` from metadata file /var/lib/clickhouse/store/72e/72e8cccc-d01c-48de-9c15-1f652f3a0118/hypothesis_test_test2.sql from query ATTACH TABLE test_3.hypothesis_test_test2 UUID '5477f859-0503-4b73-8c63-4552642ae0f9' (`i` UInt64, `a` UInt64, `b` UInt64, INDEX t a != b TYPE hypothesis GRANULARITY 1) ENGINE = MergeTree ORDER BY i SETTINGS index_granularity = 1, min_bytes_for_wide_part = 541106134, ratio_of_defaults_for_sparse_serialization = 0.8795791864395142, replace_long_file_name_to_hash = false, max_file_name_length = 37, min_bytes_for_full_part_storage = 34031348, compact_parts_max_bytes_to_buffer = 329230274, compact_parts_max_granules_to_buffer = 104, compact_parts_merge_max_bytes_to_prefetch_part = 6975552, merge_max_block_size = 11477, 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 = 3, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 2773336, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 99972, primary_key_compress_block_size = 31029. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataPartsFromDisk(std::vector, std::allocator>>&) @ 0x0000000039704427 8. ./contrib/llvm-project/libcxx/include/vector:1454: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x000000003970c533 9. ./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>) @ 0x000000003a2e5f4a 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a2e404f 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2d3063 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7b27a 13. ./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 @ 0x0000000038308626 14. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:0: DB::createTableFromAST(DB::ASTCreateQuery, String const&, String const&, std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000003294a31d 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::DatabaseOrdinary::loadTableFromMetadata(std::shared_ptr, String const&, DB::QualifiedTableName const&, std::shared_ptr const&, DB::LoadingStrictnessLevel) @ 0x00000000329c9071 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000329e2adb 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000207110e6 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000020712b00 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 22. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:22.582992 [ 3230 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:22.895356 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:22.898409 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:23.070720 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:23.429932 [ 3101 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:23.584263 [ 3447 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:23.616749 [ 9678 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x00000000315a10ad 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159da2f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b6b4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa269fb 10. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:23.759120 [ 18542 ] {358bbacb-04a2-4e53-a2e9-14c3f5256ae6} virtual void DB::StorageBuffer::flushAndPrepareForShutdown(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/StorageBuffer.cpp:0: DB::StorageBuffer::flushAllBuffers(bool) @ 0x0000000038ddb12c 8. ./build_docker/./src/Storages/StorageBuffer.cpp:0: DB::StorageBuffer::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x0000000038dda6c8 9. ./contrib/llvm-project/libcxx/include/vector:438: DB::StorageBuffer::flushAndPrepareForShutdown() @ 0x0000000038dd9ed3 10. ./contrib/llvm-project/libcxx/include/__tree:189: DB::DatabaseWithOwnTablesBase::shutdown() @ 0x0000000032af5d23 11. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:184: DB::DatabaseOnDisk::shutdown() @ 0x000000003294d62a 12. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:606: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339a9704 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000003489aca0 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:23.804216 [ 18542 ] {358bbacb-04a2-4e53-a2e9-14c3f5256ae6} executeQuery: Code: 722. DB::Exception: Waited job failed: Code: 695. DB::Exception: Load job 'load table test_3.hypothesis_test_test2' failed: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0): Cannot attach table `test_3`.`hypothesis_test_test2` from metadata file /var/lib/clickhouse/store/72e/72e8cccc-d01c-48de-9c15-1f652f3a0118/hypothesis_test_test2.sql from query ATTACH TABLE test_3.hypothesis_test_test2 UUID '5477f859-0503-4b73-8c63-4552642ae0f9' (`i` UInt64, `a` UInt64, `b` UInt64, INDEX t a != b TYPE hypothesis GRANULARITY 1) ENGINE = MergeTree ORDER BY i SETTINGS index_granularity = 1, min_bytes_for_wide_part = 541106134, ratio_of_defaults_for_sparse_serialization = 0.8795791864395142, replace_long_file_name_to_hash = false, max_file_name_length = 37, min_bytes_for_full_part_storage = 34031348, compact_parts_max_bytes_to_buffer = 329230274, compact_parts_max_granules_to_buffer = 104, compact_parts_merge_max_bytes_to_prefetch_part = 6975552, merge_max_block_size = 11477, 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 = 3, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 2773336, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 99972, primary_key_compress_block_size = 31029. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataPartsFromDisk(std::vector, std::allocator>>&) @ 0x0000000039704427 8. ./contrib/llvm-project/libcxx/include/vector:1454: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x000000003970c533 9. ./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>) @ 0x000000003a2e5f4a 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a2e404f 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2d3063 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7b27a 13. ./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 @ 0x0000000038308626 14. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:0: DB::createTableFromAST(DB::ASTCreateQuery, String const&, String const&, std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000003294a31d 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::DatabaseOrdinary::loadTableFromMetadata(std::shared_ptr, String const&, DB::QualifiedTableName const&, std::shared_ptr const&, DB::LoadingStrictnessLevel) @ 0x00000000329c9071 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000329e2adb 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000207110e6 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000020712b00 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 22. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)). (ASYNC_LOAD_FAILED) (version 24.8.14.10542.altinitytest (altinity build)). (ASYNC_LOAD_WAIT_FAILED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:49118) (comment: 01160_table_dependencies.sh) (in query: attach database test_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Common/AsyncLoader.cpp:444: DB::AsyncLoader::wait(std::shared_ptr const&, bool) @ 0x0000000020706a5b 5. ./src/Common/AsyncLoader.h:547: DB::waitLoad(unsigned long, std::vector, std::allocator>> const&, bool) @ 0x000000002065a61b 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:369: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000348954b3 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:42:23.807237 [ 18542 ] {358bbacb-04a2-4e53-a2e9-14c3f5256ae6} TCPHandler: Code: 722. DB::Exception: Waited job failed: Code: 695. DB::Exception: Load job 'load table test_3.hypothesis_test_test2' failed: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0): Cannot attach table `test_3`.`hypothesis_test_test2` from metadata file /var/lib/clickhouse/store/72e/72e8cccc-d01c-48de-9c15-1f652f3a0118/hypothesis_test_test2.sql from query ATTACH TABLE test_3.hypothesis_test_test2 UUID '5477f859-0503-4b73-8c63-4552642ae0f9' (`i` UInt64, `a` UInt64, `b` UInt64, INDEX t a != b TYPE hypothesis GRANULARITY 1) ENGINE = MergeTree ORDER BY i SETTINGS index_granularity = 1, min_bytes_for_wide_part = 541106134, ratio_of_defaults_for_sparse_serialization = 0.8795791864395142, replace_long_file_name_to_hash = false, max_file_name_length = 37, min_bytes_for_full_part_storage = 34031348, compact_parts_max_bytes_to_buffer = 329230274, compact_parts_max_granules_to_buffer = 104, compact_parts_merge_max_bytes_to_prefetch_part = 6975552, merge_max_block_size = 11477, 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 = 3, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 2773336, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 99972, primary_key_compress_block_size = 31029. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataPartsFromDisk(std::vector, std::allocator>>&) @ 0x0000000039704427 8. ./contrib/llvm-project/libcxx/include/vector:1454: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x000000003970c533 9. ./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>) @ 0x000000003a2e5f4a 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a2e404f 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2d3063 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7b27a 13. ./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 @ 0x0000000038308626 14. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:0: DB::createTableFromAST(DB::ASTCreateQuery, String const&, String const&, std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000003294a31d 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::DatabaseOrdinary::loadTableFromMetadata(std::shared_ptr, String const&, DB::QualifiedTableName const&, std::shared_ptr const&, DB::LoadingStrictnessLevel) @ 0x00000000329c9071 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000329e2adb 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000207110e6 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000020712b00 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 22. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)). (ASYNC_LOAD_FAILED) (version 24.8.14.10542.altinitytest (altinity build)). (ASYNC_LOAD_WAIT_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Common/AsyncLoader.cpp:444: DB::AsyncLoader::wait(std::shared_ptr const&, bool) @ 0x0000000020706a5b 5. ./src/Common/AsyncLoader.h:547: DB::waitLoad(unsigned long, std::vector, std::allocator>> const&, bool) @ 0x000000002065a61b 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:369: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000348954b3 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:42:23.936609 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:23.953989 [ 4745 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:24.175922 [ 18542 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:24.430757 [ 3158 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:24.430983 [ 18542 ] {f3dcf7bd-6a23-4328-ab52-6e764f53c97d} executeQuery: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:49252) (comment: 01160_table_dependencies.sh) (in query: detach database test_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:666: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x00000000339ae146 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000349459ff 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:24.434453 [ 18542 ] {f3dcf7bd-6a23-4328-ab52-6e764f53c97d} TCPHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:666: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x00000000339ae146 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000349459ff 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:24.585263 [ 3118 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:24.738150 [ 7565 ] {07413544-767b-42ef-af5f-829ddcde8785} DatabaseReplicated (test_11): It's not recommended to explicitly specify zookeeper_path and replica_name in ReplicatedMergeTree arguments 2025.10.23 23:42:24.739226 [ 7565 ] {07413544-767b-42ef-af5f-829ddcde8785} executeQuery: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:49258) (comment: 00754_alter_modify_order_by_replicated_zookeeper_long.sql) (in query: CREATE TABLE old_style(d Date, x UInt32) ENGINE ReplicatedMergeTree('/clickhouse/tables/{database}/test_00754/old_style', 'r1', d, x, 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000032a4a38c 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000032a4fcff 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a51799 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfab2 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:24.740712 [ 7565 ] {07413544-767b-42ef-af5f-829ddcde8785} TCPHandler: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000032a4a38c 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000032a4fcff 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a51799 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfab2 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:24.982558 [ 18542 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:25.102571 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:25.262382 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:25.431661 [ 3369 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:25.514765 [ 18542 ] {699fc4d0-e601-45f1-9c81-8bfcfd29ec69} TablesLoader: Tables test_3.dist_01247 depend on default.number, but seems like that does not exist. Will ignore it and try to load existing tables 2025.10.23 23:42:25.586313 [ 3505 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:25.845462 [ 22133 ] {} void DB::AsyncLoader::worker(Pool &): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2): Cannot attach table `test_3`.`hypothesis_test_test` from metadata file /var/lib/clickhouse/store/72e/72e8cccc-d01c-48de-9c15-1f652f3a0118/hypothesis_test_test.sql from query ATTACH TABLE test_3.hypothesis_test_test UUID 'efe0c3ba-7c81-4632-80f6-9a80699e38e3' (`i` UInt64, `a` UInt64, `b` UInt64, `c` Float64, INDEX t a < b TYPE hypothesis GRANULARITY 1, INDEX t2 b <= c TYPE hypothesis GRANULARITY 1) ENGINE = MergeTree ORDER BY i SETTINGS index_granularity = 1, min_bytes_for_wide_part = 541106134, ratio_of_defaults_for_sparse_serialization = 0.8795791864395142, replace_long_file_name_to_hash = false, max_file_name_length = 37, min_bytes_for_full_part_storage = 34031348, compact_parts_max_bytes_to_buffer = 329230274, compact_parts_max_granules_to_buffer = 104, compact_parts_merge_max_bytes_to_prefetch_part = 6975552, merge_max_block_size = 11477, 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 = 3, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 2773336, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 99972, primary_key_compress_block_size = 31029. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x0000000039709f85 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>) @ 0x000000003a2e5f4a 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a2e404f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2d3063 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7b27a 12. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x0000000038308626 13. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:0: DB::createTableFromAST(DB::ASTCreateQuery, String const&, String const&, std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000003294a31d 14. ./contrib/llvm-project/libcxx/include/string:1499: DB::DatabaseOrdinary::loadTableFromMetadata(std::shared_ptr, String const&, DB::QualifiedTableName const&, std::shared_ptr const&, DB::LoadingStrictnessLevel) @ 0x00000000329c9071 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000329e2adb 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000207110e6 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000020712b00 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 21. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:26.058150 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:26.207198 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:26.346119 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:26.432675 [ 3172 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:26.587454 [ 3347 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:27.100475 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:27.180068 [ 4164 ] {} void DB::AsyncLoader::worker(Pool &): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=16, jobs=16): Cannot attach table `test_3`.`table1` from metadata file /var/lib/clickhouse/store/72e/72e8cccc-d01c-48de-9c15-1f652f3a0118/table1.sql from query ATTACH TABLE test_3.table1 UUID 'b8db3d6a-6199-4d9d-9ab7-f9a99f2d7089' (`id` Int64, `v` UInt64) ENGINE = ReplicatedReplacingMergeTree('/clickhouse/tables/test_3/test_table12', '1', v) PARTITION BY id % 200 ORDER BY id SETTINGS index_granularity = 15186, min_bytes_for_wide_part = 540145247, 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 = 120218567, compact_parts_max_granules_to_buffer = 204, compact_parts_merge_max_bytes_to_prefetch_part = 9143981, merge_max_block_size = 13263, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 868585, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 5776731, concurrent_part_removal_threshold = 5, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 75573, primary_key_compress_block_size = 44841. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataPartsFromDisk(std::vector, std::allocator>>&) @ 0x0000000039704427 8. ./contrib/llvm-project/libcxx/include/vector:1454: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x000000003970c533 9. ./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) @ 0x00000000386f45bc 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, void>(std::allocator const&, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003a2e359e 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2d2f53 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7b27a 13. ./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 @ 0x0000000038308626 14. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:0: DB::createTableFromAST(DB::ASTCreateQuery, String const&, String const&, std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000003294a31d 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::DatabaseOrdinary::loadTableFromMetadata(std::shared_ptr, String const&, DB::QualifiedTableName const&, std::shared_ptr const&, DB::LoadingStrictnessLevel) @ 0x00000000329c9071 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000329e2adb 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000207110e6 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000020712b00 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 22. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:27.272434 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:27.372698 [ 18542 ] {699fc4d0-e601-45f1-9c81-8bfcfd29ec69} executeQuery: Code: 722. DB::Exception: Waited job failed: Code: 695. DB::Exception: Load job 'load table test_3.table1' failed: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=16, jobs=16): Cannot attach table `test_3`.`table1` from metadata file /var/lib/clickhouse/store/72e/72e8cccc-d01c-48de-9c15-1f652f3a0118/table1.sql from query ATTACH TABLE test_3.table1 UUID 'b8db3d6a-6199-4d9d-9ab7-f9a99f2d7089' (`id` Int64, `v` UInt64) ENGINE = ReplicatedReplacingMergeTree('/clickhouse/tables/test_3/test_table12', '1', v) PARTITION BY id % 200 ORDER BY id SETTINGS index_granularity = 15186, min_bytes_for_wide_part = 540145247, 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 = 120218567, compact_parts_max_granules_to_buffer = 204, compact_parts_merge_max_bytes_to_prefetch_part = 9143981, merge_max_block_size = 13263, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 868585, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 5776731, concurrent_part_removal_threshold = 5, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 75573, primary_key_compress_block_size = 44841. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataPartsFromDisk(std::vector, std::allocator>>&) @ 0x0000000039704427 8. ./contrib/llvm-project/libcxx/include/vector:1454: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x000000003970c533 9. ./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) @ 0x00000000386f45bc 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, void>(std::allocator const&, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003a2e359e 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2d2f53 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7b27a 13. ./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 @ 0x0000000038308626 14. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:0: DB::createTableFromAST(DB::ASTCreateQuery, String const&, String const&, std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000003294a31d 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::DatabaseOrdinary::loadTableFromMetadata(std::shared_ptr, String const&, DB::QualifiedTableName const&, std::shared_ptr const&, DB::LoadingStrictnessLevel) @ 0x00000000329c9071 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000329e2adb 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000207110e6 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000020712b00 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 22. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)). (ASYNC_LOAD_FAILED) (version 24.8.14.10542.altinitytest (altinity build)). (ASYNC_LOAD_WAIT_FAILED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:41582) (comment: 01160_table_dependencies.sh) (in query: attach database test_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Common/AsyncLoader.cpp:444: DB::AsyncLoader::wait(std::shared_ptr const&, bool) @ 0x0000000020706a5b 5. ./src/Common/AsyncLoader.h:547: DB::waitLoad(unsigned long, std::vector, std::allocator>> const&, bool) @ 0x000000002065a61b 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:369: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000348954b3 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:42:27.376669 [ 18542 ] {699fc4d0-e601-45f1-9c81-8bfcfd29ec69} TCPHandler: Code: 722. DB::Exception: Waited job failed: Code: 695. DB::Exception: Load job 'load table test_3.table1' failed: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=16, jobs=16): Cannot attach table `test_3`.`table1` from metadata file /var/lib/clickhouse/store/72e/72e8cccc-d01c-48de-9c15-1f652f3a0118/table1.sql from query ATTACH TABLE test_3.table1 UUID 'b8db3d6a-6199-4d9d-9ab7-f9a99f2d7089' (`id` Int64, `v` UInt64) ENGINE = ReplicatedReplacingMergeTree('/clickhouse/tables/test_3/test_table12', '1', v) PARTITION BY id % 200 ORDER BY id SETTINGS index_granularity = 15186, min_bytes_for_wide_part = 540145247, 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 = 120218567, compact_parts_max_granules_to_buffer = 204, compact_parts_merge_max_bytes_to_prefetch_part = 9143981, merge_max_block_size = 13263, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 868585, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 5776731, concurrent_part_removal_threshold = 5, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 75573, primary_key_compress_block_size = 44841. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataPartsFromDisk(std::vector, std::allocator>>&) @ 0x0000000039704427 8. ./contrib/llvm-project/libcxx/include/vector:1454: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x000000003970c533 9. ./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) @ 0x00000000386f45bc 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, void>(std::allocator const&, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003a2e359e 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2d2f53 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7b27a 13. ./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 @ 0x0000000038308626 14. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:0: DB::createTableFromAST(DB::ASTCreateQuery, String const&, String const&, std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000003294a31d 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::DatabaseOrdinary::loadTableFromMetadata(std::shared_ptr, String const&, DB::QualifiedTableName const&, std::shared_ptr const&, DB::LoadingStrictnessLevel) @ 0x00000000329c9071 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000329e2adb 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000207110e6 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000020712b00 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 22. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)). (ASYNC_LOAD_FAILED) (version 24.8.14.10542.altinitytest (altinity build)). (ASYNC_LOAD_WAIT_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Common/AsyncLoader.cpp:444: DB::AsyncLoader::wait(std::shared_ptr const&, bool) @ 0x0000000020706a5b 5. ./src/Common/AsyncLoader.h:547: DB::waitLoad(unsigned long, std::vector, std::allocator>> const&, bool) @ 0x000000002065a61b 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:369: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000348954b3 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:42:27.416724 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:27.433588 [ 3179 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:27.588901 [ 3561 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:28.187243 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:28.198341 [ 7565 ] {e61b7a41-ccf5-4255-affc-7ab2ee2ffedf} executeQuery: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:41644) (comment: 01160_table_dependencies.sh) (in query: detach database test_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:666: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x00000000339ae146 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000349459ff 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:28.201629 [ 7565 ] {e61b7a41-ccf5-4255-affc-7ab2ee2ffedf} TCPHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:666: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x00000000339ae146 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000349459ff 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:28.334141 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:28.434666 [ 3498 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:28.468930 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:28.590194 [ 3273 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:29.237453 [ 7565 ] {fa7da1a4-0717-42b6-9f5e-d6da4dc9c7ce} TablesLoader: Tables test_3.dist_01247 depend on default.number, but seems like that does not exist. Will ignore it and try to load existing tables 2025.10.23 23:42:29.346949 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:29.394290 [ 13713 ] {} void DB::AsyncLoader::worker(Pool &): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=4): Cannot attach table `test_3`.`table_00609` from metadata file /var/lib/clickhouse/store/72e/72e8cccc-d01c-48de-9c15-1f652f3a0118/table_00609.sql from query ATTACH TABLE test_3.table_00609 UUID '68453d5d-ab6d-4991-a02a-07cffc418701' (`key` UInt64, `val` UInt64, `def` UInt64 DEFAULT val + 1) ENGINE = MergeTree ORDER BY key SETTINGS index_granularity = 8192, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 49, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 400014129, compact_parts_max_granules_to_buffer = 234, compact_parts_merge_max_bytes_to_prefetch_part = 1105356, merge_max_block_size = 6169, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 22767327, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 52259, primary_key_compress_block_size = 8932. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataPartsFromDisk(std::vector, std::allocator>>&) @ 0x0000000039704427 8. ./contrib/llvm-project/libcxx/include/vector:1454: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x000000003970c533 9. ./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>) @ 0x000000003a2e5f4a 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a2e404f 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2d3063 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7b27a 13. ./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 @ 0x0000000038308626 14. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:0: DB::createTableFromAST(DB::ASTCreateQuery, String const&, String const&, std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000003294a31d 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::DatabaseOrdinary::loadTableFromMetadata(std::shared_ptr, String const&, DB::QualifiedTableName const&, std::shared_ptr const&, DB::LoadingStrictnessLevel) @ 0x00000000329c9071 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000329e2adb 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000207110e6 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000020712b00 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 22. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:29.436030 [ 3245 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:29.443015 [ 4745 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:29.590289 [ 7565 ] {fa7da1a4-0717-42b6-9f5e-d6da4dc9c7ce} executeQuery: Code: 722. DB::Exception: Waited job failed: Code: 695. DB::Exception: Load job 'load table test_3.table_00609' failed: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=4): Cannot attach table `test_3`.`table_00609` from metadata file /var/lib/clickhouse/store/72e/72e8cccc-d01c-48de-9c15-1f652f3a0118/table_00609.sql from query ATTACH TABLE test_3.table_00609 UUID '68453d5d-ab6d-4991-a02a-07cffc418701' (`key` UInt64, `val` UInt64, `def` UInt64 DEFAULT val + 1) ENGINE = MergeTree ORDER BY key SETTINGS index_granularity = 8192, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 49, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 400014129, compact_parts_max_granules_to_buffer = 234, compact_parts_merge_max_bytes_to_prefetch_part = 1105356, merge_max_block_size = 6169, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 22767327, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 52259, primary_key_compress_block_size = 8932. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataPartsFromDisk(std::vector, std::allocator>>&) @ 0x0000000039704427 8. ./contrib/llvm-project/libcxx/include/vector:1454: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x000000003970c533 9. ./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>) @ 0x000000003a2e5f4a 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a2e404f 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2d3063 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7b27a 13. ./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 @ 0x0000000038308626 14. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:0: DB::createTableFromAST(DB::ASTCreateQuery, String const&, String const&, std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000003294a31d 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::DatabaseOrdinary::loadTableFromMetadata(std::shared_ptr, String const&, DB::QualifiedTableName const&, std::shared_ptr const&, DB::LoadingStrictnessLevel) @ 0x00000000329c9071 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000329e2adb 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000207110e6 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000020712b00 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 22. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)). (ASYNC_LOAD_FAILED) (version 24.8.14.10542.altinitytest (altinity build)). (ASYNC_LOAD_WAIT_FAILED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:41680) (comment: 01160_table_dependencies.sh) (in query: attach database test_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Common/AsyncLoader.cpp:444: DB::AsyncLoader::wait(std::shared_ptr const&, bool) @ 0x0000000020706a5b 5. ./src/Common/AsyncLoader.h:547: DB::waitLoad(unsigned long, std::vector, std::allocator>> const&, bool) @ 0x000000002065a61b 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:369: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000348954b3 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:42:29.591177 [ 3112 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:29.592674 [ 7565 ] {fa7da1a4-0717-42b6-9f5e-d6da4dc9c7ce} TCPHandler: Code: 722. DB::Exception: Waited job failed: Code: 695. DB::Exception: Load job 'load table test_3.table_00609' failed: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=4): Cannot attach table `test_3`.`table_00609` from metadata file /var/lib/clickhouse/store/72e/72e8cccc-d01c-48de-9c15-1f652f3a0118/table_00609.sql from query ATTACH TABLE test_3.table_00609 UUID '68453d5d-ab6d-4991-a02a-07cffc418701' (`key` UInt64, `val` UInt64, `def` UInt64 DEFAULT val + 1) ENGINE = MergeTree ORDER BY key SETTINGS index_granularity = 8192, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 49, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 400014129, compact_parts_max_granules_to_buffer = 234, compact_parts_merge_max_bytes_to_prefetch_part = 1105356, merge_max_block_size = 6169, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 22767327, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 52259, primary_key_compress_block_size = 8932. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataPartsFromDisk(std::vector, std::allocator>>&) @ 0x0000000039704427 8. ./contrib/llvm-project/libcxx/include/vector:1454: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x000000003970c533 9. ./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>) @ 0x000000003a2e5f4a 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a2e404f 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2d3063 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7b27a 13. ./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 @ 0x0000000038308626 14. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:0: DB::createTableFromAST(DB::ASTCreateQuery, String const&, String const&, std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000003294a31d 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::DatabaseOrdinary::loadTableFromMetadata(std::shared_ptr, String const&, DB::QualifiedTableName const&, std::shared_ptr const&, DB::LoadingStrictnessLevel) @ 0x00000000329c9071 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000329e2adb 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000207110e6 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000020712b00 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 22. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)). (ASYNC_LOAD_FAILED) (version 24.8.14.10542.altinitytest (altinity build)). (ASYNC_LOAD_WAIT_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Common/AsyncLoader.cpp:444: DB::AsyncLoader::wait(std::shared_ptr const&, bool) @ 0x0000000020706a5b 5. ./src/Common/AsyncLoader.h:547: DB::waitLoad(unsigned long, std::vector, std::allocator>> const&, bool) @ 0x000000002065a61b 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:369: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000348954b3 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:42:29.598180 [ 18542 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:30.231959 [ 7565 ] {c34b3fc0-d905-41a1-878d-acb1696eb113} executeQuery: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:41728) (comment: 01160_table_dependencies.sh) (in query: detach database test_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:666: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x00000000339ae146 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000349459ff 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:30.234433 [ 7565 ] {c34b3fc0-d905-41a1-878d-acb1696eb113} TCPHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:666: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x00000000339ae146 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000349459ff 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:30.405698 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:30.437200 [ 3467 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:30.490852 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:30.592083 [ 3440 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:30.638541 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:31.067419 [ 7565 ] {0c179580-fece-4029-9524-94bec553c849} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:41764) (comment: 01160_table_dependencies.sh) (in query: attach database test_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202dea34 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseOnDisk::iterateMetadataFiles(std::shared_ptr, std::function const&) const @ 0x0000000032969434 7. ./build_docker/./src/Databases/DatabaseOrdinary.cpp:0: DB::DatabaseOrdinary::loadTablesMetadata(std::shared_ptr, DB::ParsedTablesMetadata&, bool) @ 0x00000000329c6c86 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:158: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000349199d0 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000348953f8 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:42:31.071945 [ 7565 ] {0c179580-fece-4029-9524-94bec553c849} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202dea34 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseOnDisk::iterateMetadataFiles(std::shared_ptr, std::function const&) const @ 0x0000000032969434 7. ./build_docker/./src/Databases/DatabaseOrdinary.cpp:0: DB::DatabaseOrdinary::loadTablesMetadata(std::shared_ptr, DB::ParsedTablesMetadata&, bool) @ 0x00000000329c6c86 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:158: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000349199d0 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000348953f8 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:42:31.116555 [ 18540 ] {5cdb5aa7-8429-42fa-b1c7-9bf439e76fda} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56452) (comment: 01896_jit_aggregation_function_if_long.sql) (in query: DROP DATABASE IF EXISTS test_7cziy2aw ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:42:31.120434 [ 18540 ] {5cdb5aa7-8429-42fa-b1c7-9bf439e76fda} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:31.145240 [ 9678 ] {e7078a5d-3fe3-4bc2-8e6e-d8831be45b47} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:39424) (comment: 01896_jit_aggregation_function_if_long.sql) (in query: DROP DATABASE IF EXISTS test_7cziy2aw ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:42:31.148677 [ 9678 ] {e7078a5d-3fe3-4bc2-8e6e-d8831be45b47} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:31.438157 [ 3223 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:31.456860 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:31.558442 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:31.593033 [ 3203 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:31.686343 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:31.693405 [ 4745 ] {f0297c2f-bd9f-4002-8858-a95f05abb3ff} executeQuery: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:41792) (comment: 01160_table_dependencies.sh) (in query: detach database test_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:666: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x00000000339ae146 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000349459ff 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:31.698149 [ 4745 ] {f0297c2f-bd9f-4002-8858-a95f05abb3ff} TCPHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:666: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x00000000339ae146 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000349459ff 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:32.280462 [ 7565 ] {100f4d0e-4029-420a-970f-862ba7459327} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=748). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:41782) (comment: 02968_url_args.sql) (in query: show create 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:42:32.283398 [ 7565 ] {100f4d0e-4029-420a-970f-862ba7459327} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=748). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:42:32.438962 [ 3561 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:32.498570 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:32.593912 [ 3555 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:32.595922 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:32.681888 [ 9678 ] {3f9e28b8-ab9e-4017-9f55-e1c7d6c55707} TablesLoader: Tables test_3.dist_01247 depend on default.number, but seems like that does not exist. Will ignore it and try to load existing tables 2025.10.23 23:42:32.953151 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:33.439993 [ 3534 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:33.528359 [ 4745 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:33.594882 [ 3533 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:33.674303 [ 4745 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:34.036373 [ 4745 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:34.440958 [ 3516 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:34.596023 [ 3514 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:34.613354 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:34.726477 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:35.080730 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:35.156364 [ 3845 ] {} void DB::AsyncLoader::worker(Pool &): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2): Cannot attach table `test_3`.`table1` from metadata file /var/lib/clickhouse/store/72e/72e8cccc-d01c-48de-9c15-1f652f3a0118/table1.sql from query ATTACH TABLE test_3.table1 UUID 'b8db3d6a-6199-4d9d-9ab7-f9a99f2d7089' (`id` Int64, `v` UInt64) ENGINE = ReplicatedReplacingMergeTree('/clickhouse/tables/test_3/test_table12', '1', v) PARTITION BY id % 200 ORDER BY id SETTINGS index_granularity = 15186, min_bytes_for_wide_part = 540145247, 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 = 120218567, compact_parts_max_granules_to_buffer = 204, compact_parts_merge_max_bytes_to_prefetch_part = 9143981, merge_max_block_size = 13263, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 868585, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 5776731, concurrent_part_removal_threshold = 5, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 75573, primary_key_compress_block_size = 44841. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataPartsFromDisk(std::vector, std::allocator>>&) @ 0x0000000039704427 8. ./contrib/llvm-project/libcxx/include/vector:1454: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x000000003970c533 9. ./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) @ 0x00000000386f45bc 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, void>(std::allocator const&, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003a2e359e 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2d2f53 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7b27a 13. ./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 @ 0x0000000038308626 14. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:0: DB::createTableFromAST(DB::ASTCreateQuery, String const&, String const&, std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000003294a31d 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::DatabaseOrdinary::loadTableFromMetadata(std::shared_ptr, String const&, DB::QualifiedTableName const&, std::shared_ptr const&, DB::LoadingStrictnessLevel) @ 0x00000000329c9071 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000329e2adb 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000207110e6 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000020712b00 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 22. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:35.441774 [ 3502 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:35.597132 [ 3498 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:35.632665 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:35.776834 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:36.070446 [ 20772 ] {076aa7c8-01cc-4614-ba6f-d7b220ae350a} ExternalDictionariesLoader: Could not update external dictionary '8f9fe562-8180-438a-ae6f-86f9d7c95511', leaving the previous version: Code: 489. DB::Exception: Cannot parse abcde for data type Int64, Reason is: Code: 632. DB::Exception: Unexpected data 'abcde' after parsed Number value '0'. (UNEXPECTED_DATA_AFTER_PARSED_VALUE) (version 24.8.14.10542.altinitytest (altinity build)). (INCORRECT_DICTIONARY_DEFINITION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String&&) @ 0x0000000009627357 4. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:85: DB::(anonymous namespace)::parseStringToField(String const&, std::shared_ptr) @ 0x0000000020e3dd13 5. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:0: DB::RegExpTreeDictionary::initRegexNodes(DB::Block&) @ 0x0000000020e36579 6. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:321: DB::RegExpTreeDictionary::loadData() @ 0x0000000020e3f78a 7. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:0: DB::RegExpTreeDictionary::RegExpTreeDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::RegExpTreeDictionary::Configuration, bool, bool, bool) @ 0x0000000020e4563b 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:303: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x0000000020e61b08 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000306b3631 10. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:0: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x00000000306b1560 11. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x0000000034790359 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:0: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000347bebca 13. ./build_docker/./src/Interpreters/ExternalLoader.cpp:0: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000347ba2d2 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000347c985b 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000347c92bf 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:36.073834 [ 7565 ] {076aa7c8-01cc-4614-ba6f-d7b220ae350a} executeQuery: Code: 489. DB::Exception: Cannot parse abcde for data type Int64, Reason is: Code: 632. DB::Exception: Unexpected data 'abcde' after parsed Number value '0'. (UNEXPECTED_DATA_AFTER_PARSED_VALUE) (version 24.8.14.10542.altinitytest (altinity build)). (INCORRECT_DICTIONARY_DEFINITION) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:41920) (comment: 02504_regexp_dictionary_yaml_source.sh) (in query: system reload dictionary regexp_dict1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String&&) @ 0x0000000009627357 4. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:85: DB::(anonymous namespace)::parseStringToField(String const&, std::shared_ptr) @ 0x0000000020e3dd13 5. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:0: DB::RegExpTreeDictionary::initRegexNodes(DB::Block&) @ 0x0000000020e36579 6. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:321: DB::RegExpTreeDictionary::loadData() @ 0x0000000020e3f78a 7. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:0: DB::RegExpTreeDictionary::RegExpTreeDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::RegExpTreeDictionary::Configuration, bool, bool, bool) @ 0x0000000020e4563b 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:303: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x0000000020e61b08 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000306b3631 10. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:0: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x00000000306b1560 11. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x0000000034790359 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:0: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000347bebca 13. ./build_docker/./src/Interpreters/ExternalLoader.cpp:0: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000347ba2d2 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000347c985b 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000347c92bf 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:36.075330 [ 7565 ] {076aa7c8-01cc-4614-ba6f-d7b220ae350a} TCPHandler: Code: 489. DB::Exception: Cannot parse abcde for data type Int64, Reason is: Code: 632. DB::Exception: Unexpected data 'abcde' after parsed Number value '0'. (UNEXPECTED_DATA_AFTER_PARSED_VALUE) (version 24.8.14.10542.altinitytest (altinity build)). (INCORRECT_DICTIONARY_DEFINITION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String&&) @ 0x0000000009627357 4. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:85: DB::(anonymous namespace)::parseStringToField(String const&, std::shared_ptr) @ 0x0000000020e3dd13 5. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:0: DB::RegExpTreeDictionary::initRegexNodes(DB::Block&) @ 0x0000000020e36579 6. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:321: DB::RegExpTreeDictionary::loadData() @ 0x0000000020e3f78a 7. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:0: DB::RegExpTreeDictionary::RegExpTreeDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::RegExpTreeDictionary::Configuration, bool, bool, bool) @ 0x0000000020e4563b 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:303: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x0000000020e61b08 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000306b3631 10. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:0: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x00000000306b1560 11. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x0000000034790359 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:0: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000347bebca 13. ./build_docker/./src/Interpreters/ExternalLoader.cpp:0: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000347ba2d2 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000347c985b 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000347c92bf 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:36.098093 [ 9678 ] {3f9e28b8-ab9e-4017-9f55-e1c7d6c55707} executeQuery: Code: 722. DB::Exception: Waited job failed: Code: 695. DB::Exception: Load job 'load table test_3.table1' failed: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2): Cannot attach table `test_3`.`table1` from metadata file /var/lib/clickhouse/store/72e/72e8cccc-d01c-48de-9c15-1f652f3a0118/table1.sql from query ATTACH TABLE test_3.table1 UUID 'b8db3d6a-6199-4d9d-9ab7-f9a99f2d7089' (`id` Int64, `v` UInt64) ENGINE = ReplicatedReplacingMergeTree('/clickhouse/tables/test_3/test_table12', '1', v) PARTITION BY id % 200 ORDER BY id SETTINGS index_granularity = 15186, min_bytes_for_wide_part = 540145247, 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 = 120218567, compact_parts_max_granules_to_buffer = 204, compact_parts_merge_max_bytes_to_prefetch_part = 9143981, merge_max_block_size = 13263, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 868585, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 5776731, concurrent_part_removal_threshold = 5, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 75573, primary_key_compress_block_size = 44841. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataPartsFromDisk(std::vector, std::allocator>>&) @ 0x0000000039704427 8. ./contrib/llvm-project/libcxx/include/vector:1454: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x000000003970c533 9. ./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) @ 0x00000000386f45bc 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, void>(std::allocator const&, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003a2e359e 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2d2f53 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7b27a 13. ./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 @ 0x0000000038308626 14. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:0: DB::createTableFromAST(DB::ASTCreateQuery, String const&, String const&, std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000003294a31d 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::DatabaseOrdinary::loadTableFromMetadata(std::shared_ptr, String const&, DB::QualifiedTableName const&, std::shared_ptr const&, DB::LoadingStrictnessLevel) @ 0x00000000329c9071 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000329e2adb 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000207110e6 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000020712b00 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 22. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)). (ASYNC_LOAD_FAILED) (version 24.8.14.10542.altinitytest (altinity build)). (ASYNC_LOAD_WAIT_FAILED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:41804) (comment: 01160_table_dependencies.sh) (in query: attach database test_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Common/AsyncLoader.cpp:444: DB::AsyncLoader::wait(std::shared_ptr const&, bool) @ 0x0000000020706a5b 5. ./src/Common/AsyncLoader.h:547: DB::waitLoad(unsigned long, std::vector, std::allocator>> const&, bool) @ 0x000000002065a61b 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:369: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000348954b3 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:42:36.131604 [ 9678 ] {3f9e28b8-ab9e-4017-9f55-e1c7d6c55707} TCPHandler: Code: 722. DB::Exception: Waited job failed: Code: 695. DB::Exception: Load job 'load table test_3.table1' failed: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2): Cannot attach table `test_3`.`table1` from metadata file /var/lib/clickhouse/store/72e/72e8cccc-d01c-48de-9c15-1f652f3a0118/table1.sql from query ATTACH TABLE test_3.table1 UUID 'b8db3d6a-6199-4d9d-9ab7-f9a99f2d7089' (`id` Int64, `v` UInt64) ENGINE = ReplicatedReplacingMergeTree('/clickhouse/tables/test_3/test_table12', '1', v) PARTITION BY id % 200 ORDER BY id SETTINGS index_granularity = 15186, min_bytes_for_wide_part = 540145247, 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 = 120218567, compact_parts_max_granules_to_buffer = 204, compact_parts_merge_max_bytes_to_prefetch_part = 9143981, merge_max_block_size = 13263, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 868585, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 5776731, concurrent_part_removal_threshold = 5, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 75573, primary_key_compress_block_size = 44841. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataPartsFromDisk(std::vector, std::allocator>>&) @ 0x0000000039704427 8. ./contrib/llvm-project/libcxx/include/vector:1454: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x000000003970c533 9. ./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) @ 0x00000000386f45bc 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, void>(std::allocator const&, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003a2e359e 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2d2f53 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7b27a 13. ./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 @ 0x0000000038308626 14. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:0: DB::createTableFromAST(DB::ASTCreateQuery, String const&, String const&, std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000003294a31d 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::DatabaseOrdinary::loadTableFromMetadata(std::shared_ptr, String const&, DB::QualifiedTableName const&, std::shared_ptr const&, DB::LoadingStrictnessLevel) @ 0x00000000329c9071 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000329e2adb 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000207110e6 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000020712b00 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 22. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)). (ASYNC_LOAD_FAILED) (version 24.8.14.10542.altinitytest (altinity build)). (ASYNC_LOAD_WAIT_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Common/AsyncLoader.cpp:444: DB::AsyncLoader::wait(std::shared_ptr const&, bool) @ 0x0000000020706a5b 5. ./src/Common/AsyncLoader.h:547: DB::waitLoad(unsigned long, std::vector, std::allocator>> const&, bool) @ 0x000000002065a61b 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:369: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000348954b3 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:42:36.159012 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:36.420578 [ 4745 ] {cd3700ee-767f-405e-b726-99f7179914ed} executeQuery: Code: 164. DB::Exception: default: Cannot execute query in readonly mode. (READONLY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:41892) (comment: 02315_readonly_create_function.sh) (in query: CREATE FUNCTION test_function AS (x) -> x + 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: auto bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000312da1bf 4. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const @ 0x00000000312d73b6 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessRightsElement const&) const @ 0x00000000312f10ac 6. ./build_docker/./src/Access/ContextAccess.cpp:0: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessRightsElements const&) const @ 0x0000000031296fcd 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessRightsElements const&) const @ 0x000000003373675b 8. ./build_docker/./src/Interpreters/InterpreterCreateFunctionQuery.cpp:0: DB::InterpreterCreateFunctionQuery::execute() @ 0x0000000035a66599 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:36.424839 [ 4745 ] {cd3700ee-767f-405e-b726-99f7179914ed} TCPHandler: Code: 164. DB::Exception: default: Cannot execute query in readonly mode. (READONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: auto bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000312da1bf 4. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const @ 0x00000000312d73b6 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessRightsElement const&) const @ 0x00000000312f10ac 6. ./build_docker/./src/Access/ContextAccess.cpp:0: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessRightsElements const&) const @ 0x0000000031296fcd 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessRightsElements const&) const @ 0x000000003373675b 8. ./build_docker/./src/Interpreters/InterpreterCreateFunctionQuery.cpp:0: DB::InterpreterCreateFunctionQuery::execute() @ 0x0000000035a66599 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:36.442604 [ 3484 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:36.598172 [ 3480 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:36.657887 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:36.748962 [ 9453 ] {7e224228-9b0e-4cfd-ac8d-0732c1d75af7} executeQuery: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37832) (comment: 01160_table_dependencies.sh) (in query: detach database test_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:666: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x00000000339ae146 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000349459ff 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:36.752459 [ 9453 ] {7e224228-9b0e-4cfd-ac8d-0732c1d75af7} TCPHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:666: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x00000000339ae146 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000349459ff 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:36.840314 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:37.216410 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:37.443629 [ 3460 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:37.599171 [ 3457 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:37.694380 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:37.894021 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:38.148496 [ 22117 ] {40d3cdad-0b50-4b31-a55e-989edc633926} ExternalDictionariesLoader: Could not update external dictionary '8f9fe562-8180-438a-ae6f-86f9d7c95511', leaving the previous version: Code: 318. DB::Exception: `regexp` should be a String. (INVALID_CONFIG_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Dictionaries/YAMLRegExpTreeDictionarySource.cpp:0: DB::parseMatchNode(unsigned long, unsigned long&, YAML::Node const&, DB::ResultColumns&, String const&, DB::DictionaryStructure const&) @ 0x0000000020c6b258 5. ./contrib/yaml-cpp/include/yaml-cpp/node/iterator.h:23: DB::parseMatchList(unsigned long, unsigned long&, YAML::Node const&, DB::ResultColumns&, String const&, DB::DictionaryStructure const&) @ 0x0000000020c6cb70 6. ./build_docker/./src/Dictionaries/YAMLRegExpTreeDictionarySource.cpp:0: DB::parseYAMLAsRegExpTree(YAML::Node const&, String const&, DB::DictionaryStructure const&) @ 0x0000000020c6d8ab 7. ./build_docker/./src/Dictionaries/YAMLRegExpTreeDictionarySource.cpp:0: DB::YAMLRegExpTreeDictionarySource::loadAll() @ 0x0000000020c73542 8. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:0: DB::RegExpTreeDictionary::loadData() @ 0x0000000020e3f625 9. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:0: DB::RegExpTreeDictionary::RegExpTreeDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::RegExpTreeDictionary::Configuration, bool, bool, bool) @ 0x0000000020e4563b 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:303: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x0000000020e61b08 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000306b3631 12. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:0: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x00000000306b1560 13. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x0000000034790359 14. ./build_docker/./src/Interpreters/ExternalLoader.cpp:0: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000347bebca 15. ./build_docker/./src/Interpreters/ExternalLoader.cpp:0: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000347ba2d2 16. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000347c985b 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000347c92bf 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:38.149339 [ 4694 ] {9c42e189-71d9-492c-ad06-ac3b9c9ab4da} TablesLoader: Tables test_3.dist_01247 depend on default.number, but seems like that does not exist. Will ignore it and try to load existing tables 2025.10.23 23:42:38.151655 [ 7565 ] {40d3cdad-0b50-4b31-a55e-989edc633926} executeQuery: Code: 318. DB::Exception: `regexp` should be a String. (INVALID_CONFIG_PARAMETER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37808) (comment: 02504_regexp_dictionary_yaml_source.sh) (in query: system reload dictionary regexp_dict1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Dictionaries/YAMLRegExpTreeDictionarySource.cpp:0: DB::parseMatchNode(unsigned long, unsigned long&, YAML::Node const&, DB::ResultColumns&, String const&, DB::DictionaryStructure const&) @ 0x0000000020c6b258 5. ./contrib/yaml-cpp/include/yaml-cpp/node/iterator.h:23: DB::parseMatchList(unsigned long, unsigned long&, YAML::Node const&, DB::ResultColumns&, String const&, DB::DictionaryStructure const&) @ 0x0000000020c6cb70 6. ./build_docker/./src/Dictionaries/YAMLRegExpTreeDictionarySource.cpp:0: DB::parseYAMLAsRegExpTree(YAML::Node const&, String const&, DB::DictionaryStructure const&) @ 0x0000000020c6d8ab 7. ./build_docker/./src/Dictionaries/YAMLRegExpTreeDictionarySource.cpp:0: DB::YAMLRegExpTreeDictionarySource::loadAll() @ 0x0000000020c73542 8. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:0: DB::RegExpTreeDictionary::loadData() @ 0x0000000020e3f625 9. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:0: DB::RegExpTreeDictionary::RegExpTreeDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::RegExpTreeDictionary::Configuration, bool, bool, bool) @ 0x0000000020e4563b 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:303: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x0000000020e61b08 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000306b3631 12. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:0: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x00000000306b1560 13. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x0000000034790359 14. ./build_docker/./src/Interpreters/ExternalLoader.cpp:0: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000347bebca 15. ./build_docker/./src/Interpreters/ExternalLoader.cpp:0: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000347ba2d2 16. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000347c985b 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000347c92bf 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:42:38.159876 [ 7565 ] {40d3cdad-0b50-4b31-a55e-989edc633926} TCPHandler: Code: 318. DB::Exception: `regexp` should be a String. (INVALID_CONFIG_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Dictionaries/YAMLRegExpTreeDictionarySource.cpp:0: DB::parseMatchNode(unsigned long, unsigned long&, YAML::Node const&, DB::ResultColumns&, String const&, DB::DictionaryStructure const&) @ 0x0000000020c6b258 5. ./contrib/yaml-cpp/include/yaml-cpp/node/iterator.h:23: DB::parseMatchList(unsigned long, unsigned long&, YAML::Node const&, DB::ResultColumns&, String const&, DB::DictionaryStructure const&) @ 0x0000000020c6cb70 6. ./build_docker/./src/Dictionaries/YAMLRegExpTreeDictionarySource.cpp:0: DB::parseYAMLAsRegExpTree(YAML::Node const&, String const&, DB::DictionaryStructure const&) @ 0x0000000020c6d8ab 7. ./build_docker/./src/Dictionaries/YAMLRegExpTreeDictionarySource.cpp:0: DB::YAMLRegExpTreeDictionarySource::loadAll() @ 0x0000000020c73542 8. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:0: DB::RegExpTreeDictionary::loadData() @ 0x0000000020e3f625 9. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:0: DB::RegExpTreeDictionary::RegExpTreeDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::RegExpTreeDictionary::Configuration, bool, bool, bool) @ 0x0000000020e4563b 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:303: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x0000000020e61b08 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000306b3631 12. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:0: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x00000000306b1560 13. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x0000000034790359 14. ./build_docker/./src/Interpreters/ExternalLoader.cpp:0: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000347bebca 15. ./build_docker/./src/Interpreters/ExternalLoader.cpp:0: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000347ba2d2 16. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000347c985b 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000347c92bf 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:42:38.238587 [ 8267 ] {} void DB::AsyncLoader::worker(Pool &): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=4): Cannot attach table `test_3`.`test_gcd` from metadata file /var/lib/clickhouse/store/72e/72e8cccc-d01c-48de-9c15-1f652f3a0118/test_gcd.sql from query ATTACH TABLE test_3.test_gcd UUID '6307d441-815e-4bd8-9f77-ef4152700532' (`test_col` UInt32 CODEC(GCD, LZ4)) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 8192, index_granularity_bytes = 1024, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 13722300, compact_parts_max_granules_to_buffer = 161, compact_parts_merge_max_bytes_to_prefetch_part = 25444396, merge_max_block_size = 3562, old_parts_lifetime = 461., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 459862, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 1, concurrent_part_removal_threshold = 8, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 64642, primary_key_compress_block_size = 79772. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataPartsFromDisk(std::vector, std::allocator>>&) @ 0x0000000039704427 8. ./contrib/llvm-project/libcxx/include/vector:1454: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x000000003970c533 9. ./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>) @ 0x000000003a2e5f4a 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a2e404f 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2d3063 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7b27a 13. ./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 @ 0x0000000038308626 14. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:0: DB::createTableFromAST(DB::ASTCreateQuery, String const&, String const&, std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000003294a31d 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::DatabaseOrdinary::loadTableFromMetadata(std::shared_ptr, String const&, DB::QualifiedTableName const&, std::shared_ptr const&, DB::LoadingStrictnessLevel) @ 0x00000000329c9071 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000329e2adb 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000207110e6 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000020712b00 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 22. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:38.302104 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:38.377907 [ 4694 ] {9c42e189-71d9-492c-ad06-ac3b9c9ab4da} executeQuery: Code: 722. DB::Exception: Waited job failed: Code: 695. DB::Exception: Load job 'load table test_3.test_gcd' failed: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=4): Cannot attach table `test_3`.`test_gcd` from metadata file /var/lib/clickhouse/store/72e/72e8cccc-d01c-48de-9c15-1f652f3a0118/test_gcd.sql from query ATTACH TABLE test_3.test_gcd UUID '6307d441-815e-4bd8-9f77-ef4152700532' (`test_col` UInt32 CODEC(GCD, LZ4)) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 8192, index_granularity_bytes = 1024, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 13722300, compact_parts_max_granules_to_buffer = 161, compact_parts_merge_max_bytes_to_prefetch_part = 25444396, merge_max_block_size = 3562, old_parts_lifetime = 461., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 459862, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 1, concurrent_part_removal_threshold = 8, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 64642, primary_key_compress_block_size = 79772. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataPartsFromDisk(std::vector, std::allocator>>&) @ 0x0000000039704427 8. ./contrib/llvm-project/libcxx/include/vector:1454: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x000000003970c533 9. ./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>) @ 0x000000003a2e5f4a 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a2e404f 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2d3063 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7b27a 13. ./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 @ 0x0000000038308626 14. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:0: DB::createTableFromAST(DB::ASTCreateQuery, String const&, String const&, std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000003294a31d 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::DatabaseOrdinary::loadTableFromMetadata(std::shared_ptr, String const&, DB::QualifiedTableName const&, std::shared_ptr const&, DB::LoadingStrictnessLevel) @ 0x00000000329c9071 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000329e2adb 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000207110e6 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000020712b00 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 22. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)). (ASYNC_LOAD_FAILED) (version 24.8.14.10542.altinitytest (altinity build)). (ASYNC_LOAD_WAIT_FAILED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37864) (comment: 01160_table_dependencies.sh) (in query: attach database test_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Common/AsyncLoader.cpp:444: DB::AsyncLoader::wait(std::shared_ptr const&, bool) @ 0x0000000020706a5b 5. ./src/Common/AsyncLoader.h:547: DB::waitLoad(unsigned long, std::vector, std::allocator>> const&, bool) @ 0x000000002065a61b 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:369: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000348954b3 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:42:38.380393 [ 4694 ] {9c42e189-71d9-492c-ad06-ac3b9c9ab4da} TCPHandler: Code: 722. DB::Exception: Waited job failed: Code: 695. DB::Exception: Load job 'load table test_3.test_gcd' failed: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=4): Cannot attach table `test_3`.`test_gcd` from metadata file /var/lib/clickhouse/store/72e/72e8cccc-d01c-48de-9c15-1f652f3a0118/test_gcd.sql from query ATTACH TABLE test_3.test_gcd UUID '6307d441-815e-4bd8-9f77-ef4152700532' (`test_col` UInt32 CODEC(GCD, LZ4)) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 8192, index_granularity_bytes = 1024, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 13722300, compact_parts_max_granules_to_buffer = 161, compact_parts_merge_max_bytes_to_prefetch_part = 25444396, merge_max_block_size = 3562, old_parts_lifetime = 461., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 459862, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 1, concurrent_part_removal_threshold = 8, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 64642, primary_key_compress_block_size = 79772. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataPartsFromDisk(std::vector, std::allocator>>&) @ 0x0000000039704427 8. ./contrib/llvm-project/libcxx/include/vector:1454: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x000000003970c533 9. ./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>) @ 0x000000003a2e5f4a 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a2e404f 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2d3063 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7b27a 13. ./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 @ 0x0000000038308626 14. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:0: DB::createTableFromAST(DB::ASTCreateQuery, String const&, String const&, std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000003294a31d 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::DatabaseOrdinary::loadTableFromMetadata(std::shared_ptr, String const&, DB::QualifiedTableName const&, std::shared_ptr const&, DB::LoadingStrictnessLevel) @ 0x00000000329c9071 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000329e2adb 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000207110e6 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000020712b00 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 22. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)). (ASYNC_LOAD_FAILED) (version 24.8.14.10542.altinitytest (altinity build)). (ASYNC_LOAD_WAIT_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Common/AsyncLoader.cpp:444: DB::AsyncLoader::wait(std::shared_ptr const&, bool) @ 0x0000000020706a5b 5. ./src/Common/AsyncLoader.h:547: DB::waitLoad(unsigned long, std::vector, std::allocator>> const&, bool) @ 0x000000002065a61b 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:369: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000348954b3 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:42:38.445049 [ 3438 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:38.600461 [ 3424 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:38.718002 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:38.977154 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:39.032836 [ 9453 ] {fb2d9986-5f7d-47bd-9366-8475990a79cd} executeQuery: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37940) (comment: 01160_table_dependencies.sh) (in query: detach database test_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:666: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x00000000339ae146 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000349459ff 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:39.035191 [ 9453 ] {fb2d9986-5f7d-47bd-9366-8475990a79cd} TCPHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:666: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x00000000339ae146 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000349459ff 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:39.367686 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:39.446046 [ 3414 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:39.601318 [ 3410 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:39.861914 [ 7565 ] {a319b687-7a45-467f-bf23-bca5fafd895b} TablesLoader: Tables test_3.dist_01247 depend on default.number, but seems like that does not exist. Will ignore it and try to load existing tables 2025.10.23 23:42:39.894526 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:40.101755 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:40.422278 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:40.446893 [ 3359 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:40.602260 [ 3323 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:40.942266 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:40.955361 [ 9453 ] {e2f91aa0-daa8-4549-b718-f0f2b2458bf4} executeQuery: Code: 57. DB::Exception: Table test_11.test already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02428_delete_with_settings.sql) (in query: /* ddl_entry=query-0000000089 */ CREATE TABLE test_11.test UUID 'c694e3a6-f4e5-40c6-a6e6-5ce5c9eff766' (`id` Int32, `key` String) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 8192, index_granularity_bytes = '10Mi', min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.6941207051277161, replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 380726423, compact_parts_max_bytes_to_buffer = 393535787, compact_parts_max_granules_to_buffer = 166, compact_parts_merge_max_bytes_to_prefetch_part = 15813884, merge_max_block_size = 22325, old_parts_lifetime = 36., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 1, concurrent_part_removal_threshold = 91, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 25262, primary_key_compress_block_size = 32938), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003395fc9e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000033958fac 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ad726d 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a52a3c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfab2 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:42:41.084461 [ 9453 ] {e2f91aa0-daa8-4549-b718-f0f2b2458bf4} executeQuery: Code: 57. DB::Exception: Table test_11.test already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37990) (comment: 02428_delete_with_settings.sql) (in query: CREATE TABLE test (`id` Int32, `key` String) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 8192, index_granularity_bytes = '10Mi', min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.6941207051277161, replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 380726423, compact_parts_max_bytes_to_buffer = 393535787, compact_parts_max_granules_to_buffer = 166, compact_parts_merge_max_bytes_to_prefetch_part = 15813884, merge_max_block_size = 22325, old_parts_lifetime = 36., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 1, concurrent_part_removal_threshold = 91, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 25262, primary_key_compress_block_size = 32938), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003395fc9e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000033958fac 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ad726d 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a52a3c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfab2 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:42:41.089364 [ 9453 ] {e2f91aa0-daa8-4549-b718-f0f2b2458bf4} TCPHandler: Code: 57. DB::Exception: Table test_11.test already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003395fc9e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000033958fac 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ad726d 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a52a3c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfab2 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:42:41.168081 [ 7565 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:41.447901 [ 3077 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:41.484216 [ 9453 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:41.603041 [ 3444 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:42.112550 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:42.221768 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:42.322521 [ 7565 ] {10704e4d-b91d-4f88-8d07-fb38c57e991e} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38086) (comment: 02504_regexp_dictionary_yaml_source.sh) (in query: drop dictionary if exists regexp_dict3;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349417ab 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:42:42.324786 [ 7565 ] {10704e4d-b91d-4f88-8d07-fb38c57e991e} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349417ab 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:42:42.448680 [ 3365 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:42.515954 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:42.603883 [ 3332 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:43.060461 [ 9453 ] {180c460b-de10-4cea-8d27-434100d1f2c8} executeQuery: Code: 630. DB::Exception: Cannot drop or rename test_3.join, because some tables depend on it: test_3.t (30a89dad-0f44-4d83-972d-c122b4b480fa), test_3.s, test_3.dict2. (HAVE_DEPENDENT_OBJECTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38070) (comment: 01160_table_dependencies.sh) (in query: rename table join to join1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x00000000339ef4ad 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1543: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x00000000339d48ff 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::removeDependencies(DB::StorageID const&, bool, bool, bool) @ 0x00000000339d3268 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:0: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000034bd824a 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:0: DB::InterpreterRenameQuery::execute() @ 0x0000000034bd28b5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:42:43.083155 [ 9453 ] {180c460b-de10-4cea-8d27-434100d1f2c8} TCPHandler: Code: 630. DB::Exception: Cannot drop or rename test_3.join, because some tables depend on it: test_3.t (30a89dad-0f44-4d83-972d-c122b4b480fa), test_3.s, test_3.dict2. (HAVE_DEPENDENT_OBJECTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x00000000339ef4ad 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1543: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x00000000339d48ff 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::removeDependencies(DB::StorageID const&, bool, bool, bool) @ 0x00000000339d3268 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:0: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000034bd824a 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:0: DB::InterpreterRenameQuery::execute() @ 0x0000000034bd28b5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:42:43.160922 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:43.300795 [ 9453 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:43.449437 [ 3129 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:43.557256 [ 9453 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:43.579073 [ 4694 ] {28a3256d-239d-4dbe-a2db-072bf391b058} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=748). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38108) (comment: 02504_regexp_dictionary_yaml_source.sh) (in query: select dictGetAll('regexp_dict4', 'pattern', 'hello\nworld');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:42:43.582361 [ 4694 ] {28a3256d-239d-4dbe-a2db-072bf391b058} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=748). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:42:43.604732 [ 3101 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:43.869520 [ 22132 ] {} ZooKeeperClient: Code: 999. Coordination::Exception: Session expired (fault injected on recv). (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000003a21d8b1 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEES0_NS_5ErrorEOS5_ @ 0x000000003cd2cd64 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1660: Coordination::ZooKeeper::maybeInjectRecvFault() @ 0x000000003cd156a2 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveEvent() @ 0x000000003cd1207c 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveThread() @ 0x000000003cd109b9 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl> const&, zkutil::ZooKeeperArgs const&, std::shared_ptr)::$_1>(Coordination::ZooKeeper::ZooKeeper(std::vector> const&, zkutil::ZooKeeperArgs const&, std::shared_ptr)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003cd2940f 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:43.870713 [ 3111 ] {} test_3.rmt (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.10.23 23:42:43.870881 [ 3074 ] {} test_3.`02691_drop_column_replicated` (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.10.23 23:42:43.871311 [ 3565 ] {} test_3.table1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.10.23 23:42:43.871489 [ 3566 ] {} test_15.r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.10.23 23:42:43.872685 [ 3561 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000003cc8de51 3. ./src/Common/ZooKeeper/IKeeper.h:509: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003cd16a3e 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003cd2369f 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe6e6d 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe5f26 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe84e7 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe81ea 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000003a10064e 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000003889f11d 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f9f 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:43.872690 [ 3124 ] {} test_3.rmt (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /test/02253/02253_empty_part_checksums_test_3/rmt/blocks. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x0000000030538e6c 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe8649 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000003cbe7761 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x000000003a061e9e 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x000000003a04fe19 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a041419 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:50: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a03dd98 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003a06697f 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:43.873445 [ 3563 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02725_start_stop_fetches_test_15/r/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:44.242046 [ 9453 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:44.387398 [ 9453 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:44.411918 [ 4694 ] {286e15c2-b01a-490e-a904-5d7587f0c771} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38154) (comment: 02504_regexp_dictionary_yaml_source.sh) (in query: drop dictionary regexp_dict4;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349417ab 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:42:44.415382 [ 4694 ] {286e15c2-b01a-490e-a904-5d7587f0c771} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349417ab 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:42:44.450290 [ 3405 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:44.605726 [ 3340 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:44.627059 [ 9453 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:44.678506 [ 18542 ] {5a65718a-89cb-4e20-96c1-d37d96ee40e9} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:55846) (comment: 02504_regexp_dictionary_yaml_source.sh) (in query: DROP DATABASE IF EXISTS test_daghdgdc ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349417ab 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>>>&) @ 0x0000000034947b8d 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:42:44.682542 [ 18542 ] {5a65718a-89cb-4e20-96c1-d37d96ee40e9} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349417ab 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>>>&) @ 0x0000000034947b8d 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:45.316305 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:45.451312 [ 3167 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:45.601606 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:45.606643 [ 3118 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:45.676816 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:45.750974 [ 2903 ] {abb59af5-9fee-4ffd-bb5e-e2e182f684a6} executeQuery: Code: 630. DB::Exception: Cannot drop or rename test_3.dict1 (ddb04029-32f6-46c6-8d5c-dc0559d6ac3c), because some tables depend on it: test_3.join, test_3.t (30a89dad-0f44-4d83-972d-c122b4b480fa). (HAVE_DEPENDENT_OBJECTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38204) (comment: 01160_table_dependencies.sh) (in query: detach dictionary dict1 permanently), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x00000000339ef4ad 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1543: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x00000000339d48ff 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::removeDependencies(DB::StorageID const&, bool, bool, bool) @ 0x00000000339d3268 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003493e249 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:42:45.802196 [ 2903 ] {abb59af5-9fee-4ffd-bb5e-e2e182f684a6} TCPHandler: Code: 630. DB::Exception: Cannot drop or rename test_3.dict1 (ddb04029-32f6-46c6-8d5c-dc0559d6ac3c), because some tables depend on it: test_3.join, test_3.t (30a89dad-0f44-4d83-972d-c122b4b480fa). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x00000000339ef4ad 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1543: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x00000000339d48ff 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::removeDependencies(DB::StorageID const&, bool, bool, bool) @ 0x00000000339d3268 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003493e249 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:42:46.370926 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:46.452305 [ 3478 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:46.607782 [ 3436 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:46.723143 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:46.763028 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:46.992276 [ 3933 ] {691da6ae-9a20-48a6-b306-e91c1b0f1665} executeQuery: Code: 69. DB::Exception: Cannot convert value '18446744073709551615' from UInt64: it cannot be represented as Float64. (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38186) (comment: 00975_values_list.sql) (in query: SELECT * FROM VALUES('x Float64', 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000861f137 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:623: DB::convertFieldToTypeOrThrow(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357d93bf 5. ./build_docker/./src/TableFunctions/TableFunctionValues.cpp:0: DB::(anonymous namespace)::TableFunctionValues::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002fe5a974 6. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f70b3 7. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000003374cff2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4838: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003345fff3 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334edd21 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436960 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 2025.10.23 23:42:46.993974 [ 3933 ] {691da6ae-9a20-48a6-b306-e91c1b0f1665} TCPHandler: Code: 69. DB::Exception: Cannot convert value '18446744073709551615' from UInt64: it cannot be represented as Float64. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000861f137 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:623: DB::convertFieldToTypeOrThrow(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357d93bf 5. ./build_docker/./src/TableFunctions/TableFunctionValues.cpp:0: DB::(anonymous namespace)::TableFunctionValues::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002fe5a974 6. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f70b3 7. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000003374cff2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4838: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003345fff3 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334edd21 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436960 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 2025.10.23 23:42:47.453056 [ 3286 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:47.456739 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:47.609116 [ 3252 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:47.814658 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:47.880320 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:48.453738 [ 3563 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:48.512622 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:48.610078 [ 3534 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:48.900915 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:48.913811 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:48.969952 [ 3933 ] {1c1181fa-9406-4746-9eaa-d00841fcd0a1} executeQuery: Code: 53. DB::Exception: Cannot convert NULL to Float64. (TYPE_MISMATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38186) (comment: 00975_values_list.sql) (in query: SELECT * FROM VALUES('x Float64', 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:618: DB::convertFieldToTypeOrThrow(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357d90c9 5. ./build_docker/./src/TableFunctions/TableFunctionValues.cpp:0: DB::(anonymous namespace)::TableFunctionValues::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002fe5a974 6. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f70b3 7. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000003374cff2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4838: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003345fff3 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334edd21 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436960 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 2025.10.23 23:42:48.971515 [ 3933 ] {1c1181fa-9406-4746-9eaa-d00841fcd0a1} TCPHandler: Code: 53. DB::Exception: Cannot convert NULL to Float64. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:618: DB::convertFieldToTypeOrThrow(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357d90c9 5. ./build_docker/./src/TableFunctions/TableFunctionValues.cpp:0: DB::(anonymous namespace)::TableFunctionValues::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002fe5a974 6. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f70b3 7. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000003374cff2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4838: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003345fff3 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334edd21 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436960 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 2025.10.23 23:42:49.438894 [ 4841 ] {8a4a9ad0-0b6c-4fa9-bc56-e8dcd1e4d476} executeQuery: Code: 630. DB::Exception: Cannot drop or rename test_3.dict1, because some tables depend on it: test_3.join, test_3.t (30a89dad-0f44-4d83-972d-c122b4b480fa). (HAVE_DEPENDENT_OBJECTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:46132) (comment: 01160_table_dependencies.sh) (in query: rename database test_3 to test_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x00000000339ef4ad 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1543: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x00000000339d48ff 5. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamed(DB::StorageID const&, bool, bool, bool) const @ 0x00000000339d6019 6. ./src/Interpreters/StorageID.h:35: DB::DatabaseAtomic::renameDatabase(std::shared_ptr, String const&) @ 0x00000000329a38e6 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterRenameQuery::executeToDatabase(DB::ASTRenameQuery const&, std::vector> const&) @ 0x0000000034bd640a 8. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:75: DB::InterpreterRenameQuery::execute() @ 0x0000000034bd288a 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:49.441587 [ 4841 ] {8a4a9ad0-0b6c-4fa9-bc56-e8dcd1e4d476} TCPHandler: Code: 630. DB::Exception: Cannot drop or rename test_3.dict1, because some tables depend on it: test_3.join, test_3.t (30a89dad-0f44-4d83-972d-c122b4b480fa). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x00000000339ef4ad 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1543: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x00000000339d48ff 5. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamed(DB::StorageID const&, bool, bool, bool) const @ 0x00000000339d6019 6. ./src/Interpreters/StorageID.h:35: DB::DatabaseAtomic::renameDatabase(std::shared_ptr, String const&) @ 0x00000000329a38e6 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterRenameQuery::executeToDatabase(DB::ASTRenameQuery const&, std::vector> const&) @ 0x0000000034bd640a 8. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:75: DB::InterpreterRenameQuery::execute() @ 0x0000000034bd288a 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:49.454387 [ 3370 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:49.611056 [ 3379 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:49.687141 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:49.963254 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:49.983819 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:50.077584 [ 4694 ] {be601309-6666-4542-8518-66aac959763f} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:36608) (comment: 02999_scalar_subqueries_bug_2.sql) (in query: DROP DATABASE IF EXISTS test_3az6bf7c ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000002ffc5e67 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003493f2d5 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>>>&) @ 0x0000000034947b8d 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:42:50.080170 [ 4694 ] {be601309-6666-4542-8518-66aac959763f} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000002ffc5e67 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003493f2d5 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>>>&) @ 0x0000000034947b8d 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:50.211245 [ 3933 ] {37c3313d-1fd2-4537-8723-ef458dbac50d} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Values. (NOT_IMPLEMENTED) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 00975_values_list.sql) (in query: /* ddl_entry=query-0000000092 */ TRUNCATE TABLE test_11.values_list), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000002ffc5e67 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003493f2d5 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003395fc9e 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000033958fac 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ad726d 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a52a3c 14. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:222: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003493e6e9 15. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 16. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 17. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 27. ? @ 0x00007f100c857ac3 28. ? @ 0x00007f100c8e9850 2025.10.23 23:42:50.220666 [ 3933 ] {37c3313d-1fd2-4537-8723-ef458dbac50d} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Values. (NOT_IMPLEMENTED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38186) (comment: 00975_values_list.sql) (in query: DROP TABLE values_list;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000002ffc5e67 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003493f2d5 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003395fc9e 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000033958fac 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ad726d 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a52a3c 14. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:222: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003493e6e9 15. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 16. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 17. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 27. ? @ 0x00007f100c857ac3 28. ? @ 0x00007f100c8e9850 2025.10.23 23:42:50.222022 [ 3933 ] {37c3313d-1fd2-4537-8723-ef458dbac50d} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000002ffc5e67 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003493f2d5 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003395fc9e 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000033958fac 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ad726d 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a52a3c 14. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:222: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003493e6e9 15. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 16. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 17. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 27. ? @ 0x00007f100c857ac3 28. ? @ 0x00007f100c8e9850 2025.10.23 23:42:50.455160 [ 3188 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:50.612168 [ 3150 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:50.863231 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:51.037043 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:51.048181 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:51.456044 [ 3507 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:51.487002 [ 7652 ] {f040f10c-79d7-4019-b1d9-fd78117fc77b} executeQuery: Code: 81. DB::Exception: Database test_3_2 does not exist. Maybe you meant test_3?. (UNKNOWN_DATABASE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:46182) (comment: 01160_table_dependencies.sh) (in query: rename table t to test_3_2.t), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:666: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x00000000339ae146 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:155: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000034bd8db7 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:0: DB::InterpreterRenameQuery::execute() @ 0x0000000034bd28b5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:42:51.491617 [ 7652 ] {f040f10c-79d7-4019-b1d9-fd78117fc77b} TCPHandler: Code: 81. DB::Exception: Database test_3_2 does not exist. Maybe you meant test_3?. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:666: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x00000000339ae146 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:155: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000034bd8db7 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:0: DB::InterpreterRenameQuery::execute() @ 0x0000000034bd28b5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:42:51.613293 [ 3485 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:51.924454 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:52.105471 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:52.154544 [ 4675 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:52.387668 [ 2903 ] {2f4da6fa-4651-421d-a581-caede1894f31} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520)) does not support transactions. (NOT_IMPLEMENTED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:46186) (comment: 02438_sync_replica_lightweight.sql) (in query: insert into rmt1 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:50: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000003488c3e5 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034bb9a5f 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 2025.10.23 23:42:52.390251 [ 2903 ] {2f4da6fa-4651-421d-a581-caede1894f31} TCPHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520)) 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:50: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000003488c3e5 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034bb9a5f 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 2025.10.23 23:42:52.456789 [ 3263 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:52.614301 [ 3217 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:53.009359 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:53.148314 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:53.197306 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:53.387220 [ 4694 ] {5dc400d8-6a74-4962-807b-df52f64952e5} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520)) does not support transactions. (NOT_IMPLEMENTED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:36626) (comment: 02438_sync_replica_lightweight.sql) (in query: DROP DATABASE IF EXISTS test_u4vuh4wv ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:50: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000003488c3e5 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003493c194 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>>>&) @ 0x0000000034947b8d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 12. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 13. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:42:53.389912 [ 4694 ] {5dc400d8-6a74-4962-807b-df52f64952e5} DynamicQueryHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520)) 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:50: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000003488c3e5 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003493c194 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>>>&) @ 0x0000000034947b8d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 12. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 13. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:53.457498 [ 3468 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:53.615332 [ 3424 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:53.658807 [ 4841 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x00000000315a10ad 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159da2f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b6b4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa269fb 10. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:54.087576 [ 18540 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:54.252724 [ 18540 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:54.338959 [ 18541 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:54.458360 [ 3282 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:54.616752 [ 3254 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:55.249281 [ 18541 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:55.415048 [ 18542 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:55.459211 [ 3088 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:55.548688 [ 18541 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:55.618005 [ 3444 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:55.723293 [ 4675 ] {9c35d533-6724-4cef-9f1c-e27c477f45b2} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:47198). (NETWORK_ERROR) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:47198) (comment: 01731_async_task_queue_wait.sh) (in query: SELECT `__table1`.`number` + sleep(0.3) AS `x` FROM `system`.`numbers` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c6938 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000003ac044bd 6. ./contrib/llvm-project/libcxx/include/__mutex_base:253: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfbb15 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 2025.10.23 23:42:55.729473 [ 4675 ] {9c35d533-6724-4cef-9f1c-e27c477f45b2} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:47198). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c6938 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000003ac2dd9a 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x000000003abff96a 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9aa8 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:55.730264 [ 4675 ] {9c35d533-6724-4cef-9f1c-e27c477f45b2} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:47198). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c6938 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000003ac044bd 6. ./contrib/llvm-project/libcxx/include/__mutex_base:253: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfbb15 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 2025.10.23 23:42:55.731679 [ 4675 ] {9c35d533-6724-4cef-9f1c-e27c477f45b2} TCPHandler: Client has gone away. 2025.10.23 23:42:55.962953 [ 3548 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:56.302202 [ 3479 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:56.341611 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:56.460267 [ 3469 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:56.469027 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:56.618969 [ 3463 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:56.639868 [ 18542 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:56.963984 [ 3374 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:57.238001 [ 9678 ] {062e32bd-e877-4e20-865a-669fbe8569d6} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:51252) (comment: 01160_table_dependencies.sh) (in query: drop dictionary dict2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349417ab 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:42:57.240615 [ 9678 ] {062e32bd-e877-4e20-865a-669fbe8569d6} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349417ab 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:42:57.302949 [ 3285 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:57.420797 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:57.461334 [ 3238 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:57.517005 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:57.620160 [ 3188 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:57.790441 [ 18540 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:57.816061 [ 7652 ] {48a483d6-750a-4328-a35e-eb8ef10287ed} 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]:39530). (NETWORK_ERROR) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:39530) (comment: 01731_async_task_queue_wait.sh) (in query: SELECT `__table1`.`number` + sleep(0.3) AS `x` FROM `system`.`numbers` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c6938 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000003ac044bd 6. ./src/Core/Block.h:37: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfc281 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 2025.10.23 23:42:57.819285 [ 7652 ] {48a483d6-750a-4328-a35e-eb8ef10287ed} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:39530). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c6938 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000003ac2dd9a 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x000000003abff96a 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9aa8 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:57.819669 [ 7652 ] {48a483d6-750a-4328-a35e-eb8ef10287ed} 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]:39530). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c6938 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000003ac044bd 6. ./src/Core/Block.h:37: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfc281 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 2025.10.23 23:42:57.820475 [ 7652 ] {48a483d6-750a-4328-a35e-eb8ef10287ed} TCPHandler: Client has gone away. 2025.10.23 23:42:57.965057 [ 3115 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:58.303725 [ 3546 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:58.462223 [ 3516 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:58.472298 [ 18540 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:58.621175 [ 3509 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:58.625398 [ 18540 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:58.876628 [ 18540 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:58.965942 [ 3499 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:59.304477 [ 3487 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:59.463142 [ 3479 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:59.488620 [ 4745 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:59.622045 [ 3473 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:59.686277 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:59.909394 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:42:59.966781 [ 3455 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:00.223136 [ 9678 ] {c766fa6e-376e-4eb3-88ac-6d6ddffa47ae} executeQuery: Code: 630. DB::Exception: Cannot drop or rename test_3.join (6f5af1e6-79f1-41f0-b623-4bc0187973c4), because some tables depend on it: test_3_1_renamed.t, test_3.s, test_3.dict2. (HAVE_DEPENDENT_OBJECTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:51362) (comment: 01160_table_dependencies.sh) (in query: drop table join;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x00000000339ef4ad 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1543: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x00000000339d48ff 5. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamed(DB::StorageID const&, bool, bool, bool) const @ 0x00000000339d6019 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003493f862 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:43:00.226271 [ 9678 ] {c766fa6e-376e-4eb3-88ac-6d6ddffa47ae} TCPHandler: Code: 630. DB::Exception: Cannot drop or rename test_3.join (6f5af1e6-79f1-41f0-b623-4bc0187973c4), because some tables depend on it: test_3_1_renamed.t, test_3.s, test_3.dict2. (HAVE_DEPENDENT_OBJECTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x00000000339ef4ad 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1543: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x00000000339d48ff 5. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamed(DB::StorageID const&, bool, bool, bool) const @ 0x00000000339d6019 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003493f862 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:43:00.305241 [ 3452 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:00.464189 [ 3451 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:00.555582 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:00.622973 [ 3436 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:00.754176 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:00.961828 [ 4745 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:00.967359 [ 9678 ] {37341a4a-6341-4b2e-b90a-8767c752aa47} executeQuery: Code: 630. DB::Exception: Cannot drop or rename test_3.dict1 (ddb04029-32f6-46c6-8d5c-dc0559d6ac3c), because some tables depend on it: test_3_1_renamed.t, test_3.join. (HAVE_DEPENDENT_OBJECTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:51392) (comment: 01160_table_dependencies.sh) (in query: drop dictionary dict1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x00000000339ef4ad 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1543: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x00000000339d48ff 5. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamed(DB::StorageID const&, bool, bool, bool) const @ 0x00000000339d6019 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003493f862 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:43:00.967530 [ 3420 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:00.969938 [ 9678 ] {37341a4a-6341-4b2e-b90a-8767c752aa47} TCPHandler: Code: 630. DB::Exception: Cannot drop or rename test_3.dict1 (ddb04029-32f6-46c6-8d5c-dc0559d6ac3c), because some tables depend on it: test_3_1_renamed.t, test_3.join. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x00000000339ef4ad 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1543: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x00000000339d48ff 5. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamed(DB::StorageID const&, bool, bool, bool) const @ 0x00000000339d6019 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003493f862 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:43:01.306108 [ 3421 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:01.419900 [ 18541 ] {76ec34f7-6072-49fb-91cd-664cc7aec718} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:51212) (comment: 01271_optimize_arithmetic_operations_in_aggr_func_long.sql) (in query: SELECT min(n + -1), min(-1 + n), min(n - -1), min(-1 - n) FROM (SELECT number n FROM numbers(10));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:43:01.424393 [ 18541 ] {76ec34f7-6072-49fb-91cd-664cc7aec718} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:43:01.464989 [ 3405 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:01.624165 [ 3399 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:01.702770 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:01.821488 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:01.968531 [ 3383 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:02.031645 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:02.307164 [ 3369 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:02.465700 [ 3366 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:02.625160 [ 3360 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:02.769760 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:02.873208 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:02.969433 [ 3343 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:03.126076 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:03.308250 [ 3339 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:03.466712 [ 3372 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:03.626469 [ 3348 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:03.908809 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:03.923327 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:03.970331 [ 3306 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:04.185614 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:04.309242 [ 3297 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:04.499999 [ 3295 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:04.706362 [ 3285 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:04.950973 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:04.968828 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:04.971353 [ 3280 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:05.281578 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:05.310213 [ 3268 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:05.501109 [ 3262 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:05.707474 [ 3254 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:05.972466 [ 3247 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:06.019304 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:06.032213 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:06.238526 [ 9678 ] {d8a22828-07b7-45ab-b10b-41633af1ac0b} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:36982) (comment: 01160_table_dependencies.sh) (in query: drop database test_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:06.241069 [ 9678 ] {d8a22828-07b7-45ab-b10b-41633af1ac0b} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:06.310935 [ 3235 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:06.336251 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:06.502015 [ 3226 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:06.709072 [ 3218 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:06.973320 [ 3214 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:07.068758 [ 9678 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:07.092368 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:07.311787 [ 3196 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:07.423071 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:07.502771 [ 3192 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:07.710151 [ 3185 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:07.974285 [ 3180 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:08.163321 [ 4694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:08.168072 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:08.312878 [ 3165 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:08.424645 [ 3164 ] {} test_3.rmt (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.10.23 23:43:08.424976 [ 3162 ] {} test_3.`02691_drop_column_replicated` (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.10.23 23:43:08.425120 [ 3159 ] {} test_3.table1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.10.23 23:43:08.425271 [ 3157 ] {} test_15.r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.10.23 23:43:08.426264 [ 3158 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02725_start_stop_fetches_test_15/r/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:08.426321 [ 3517 ] {} test_3.rmt (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /test/02253/02253_empty_part_checksums_test_3/rmt/blocks. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x0000000030538e6c 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe8649 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000003cbe7761 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x000000003a061e9e 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x000000003a04fe19 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a041419 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:50: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a03dd98 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003a06697f 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:08.426485 [ 3150 ] {} test_3.table1 (b8db3d6a-6199-4d9d-9ab7-f9a99f2d7089): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_3/test_table12/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:08.426731 [ 3155 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:08.426804 [ 3156 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000003cc8de51 3. ./src/Common/ZooKeeper/IKeeper.h:509: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003cd16a3e 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003cd2369f 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe6e6d 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe5f26 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe84e7 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe81ea 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000003a10064e 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000003889f11d 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f9f 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:08.427162 [ 3158 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:08.427447 [ 3149 ] {} test_3.table1 (b8db3d6a-6199-4d9d-9ab7-f9a99f2d7089): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000003cc8de51 3. ./src/Common/ZooKeeper/IKeeper.h:509: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003cd16a3e 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003cd2369f 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe6e6d 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe5f26 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe84e7 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe81ea 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000003a10064e 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000003889f11d 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f9f 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:08.427543 [ 3155 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000003cc8de51 3. ./src/Common/ZooKeeper/IKeeper.h:509: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003cd16a3e 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003cd2369f 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe6e6d 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe5f26 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe84e7 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe81ea 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000003a10064e 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000003889f11d 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f9f 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:08.427436 [ 4745 ] {13a7ae2b-aa44-4837-b65f-21f5031dc020} executeQuery: Code: 999. Coordination::Exception: Coordination error: Connection loss, path /test/db/test_11/max_log_ptr. (KEEPER_EXCEPTION) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:51456) (comment: 01247_optimize_distributed_group_by_sharding_key_dist_on_dist.sql) (in query: create table data_01247 as system.numbers 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x0000000030538e6c 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000003cbf6898 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003cbf5ab3 6. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ad5036 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a52a3c 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfab2 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:43:08.427549 [ 3150 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000003cc8de51 3. ./src/Common/ZooKeeper/IKeeper.h:509: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003cd16a3e 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003cd2369f 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe6e6d 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe5f26 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe84e7 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe81ea 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000003a10064e 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000003889f11d 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f9f 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:08.429993 [ 3517 ] {} test_3.rmt (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000003cc8de51 3. ./src/Common/ZooKeeper/IKeeper.h:509: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003cd16a3e 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000003cd20792 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryExistsNoThrow(String const&, std::function) @ 0x000000003cbf3581 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003cbf26a1 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000003cbf3a70 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003cbea871 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000003a0439c9 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a04133c 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:50: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a03dd98 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003a06697f 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 15. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:08.433229 [ 4745 ] {13a7ae2b-aa44-4837-b65f-21f5031dc020} TCPHandler: Code: 999. Coordination::Exception: Coordination error: Connection loss, path /test/db/test_11/max_log_ptr. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x0000000030538e6c 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000003cbf6898 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003cbf5ab3 6. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ad5036 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a52a3c 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfab2 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:43:08.479208 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:08.504085 [ 3146 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:08.711245 [ 3091 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:08.975426 [ 3391 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:09.109702 [ 2904 ] {9e2a9a9d-ed81-408f-ba8e-0ec4dfa32b9a} executeQuery: Code: 630. DB::Exception: Cannot drop or rename test_3.dict1 (ddb04029-32f6-46c6-8d5c-dc0559d6ac3c), because some tables depend on it: test_3.join. (HAVE_DEPENDENT_OBJECTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37062) (comment: 01160_table_dependencies.sh) (in query: drop dictionary if exists dict1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x00000000339ef4ad 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1543: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x00000000339d48ff 5. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamed(DB::StorageID const&, bool, bool, bool) const @ 0x00000000339d6019 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003493f862 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:43:09.112595 [ 2904 ] {9e2a9a9d-ed81-408f-ba8e-0ec4dfa32b9a} TCPHandler: Code: 630. DB::Exception: Cannot drop or rename test_3.dict1 (ddb04029-32f6-46c6-8d5c-dc0559d6ac3c), because some tables depend on it: test_3.join. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x00000000339ef4ad 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1543: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x00000000339d48ff 5. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamed(DB::StorageID const&, bool, bool, bool) const @ 0x00000000339d6019 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003493f862 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:43:09.201008 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:09.231212 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:09.313670 [ 3516 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:09.427581 [ 3497 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:09.428193 [ 3496 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:09.504843 [ 3483 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:09.557882 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:09.712289 [ 3450 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:09.976368 [ 3393 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:10.257563 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:10.284334 [ 9453 ] {0d2bc8ff-cdbb-41c1-ad25-d9cb59405a08} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37066) (comment: 00564_versioned_collapsing_merge_tree.sql) (in query: select * from mult_tab final order by date, value, sign;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202dea34 6. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039a5dbc5 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003bf2b229 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bf26bba 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003bf26345 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bf3d5b9 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2045: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf42fe0 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be48783 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003beb6da5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034cf5e6d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034cf5881 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:43:10.287681 [ 9453 ] {0d2bc8ff-cdbb-41c1-ad25-d9cb59405a08} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202dea34 6. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039a5dbc5 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003bf2b229 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bf26bba 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003bf26345 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bf3d5b9 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2045: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf42fe0 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be48783 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003beb6da5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034cf5e6d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034cf5881 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:43:10.314469 [ 3333 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:10.317810 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:10.428769 [ 3299 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:10.428998 [ 3293 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:10.505570 [ 3289 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:10.616552 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:10.713273 [ 3240 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:10.977125 [ 3202 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:11.307835 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:11.315240 [ 3080 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:11.364140 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:11.429618 [ 3443 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:11.429687 [ 3396 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:11.506528 [ 3265 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:11.689266 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:11.714330 [ 3124 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:11.760574 [ 3933 ] {db4691b2-3ce6-4449-a4b5-88a4c2f77f15} executeQuery: Code: 57. DB::Exception: Table test_3.dict_src already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37206) (comment: 01160_table_dependencies.sh) (in query: CREATE TABLE dict_src (`n` int, `m` int, `s` String) ENGINE = MergeTree ORDER BY n SETTINGS index_granularity = 40454, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189646301, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 10572573, merge_max_block_size = 5323, old_parts_lifetime = 36., prefer_fetch_merged_part_size_threshold = 1927278932, vertical_merge_algorithm_min_rows_to_activate = 682673, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 2370475839, index_granularity_bytes = 3326880, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 60501, primary_key_compress_block_size = 80459), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:43:11.765017 [ 3933 ] {db4691b2-3ce6-4449-a4b5-88a4c2f77f15} TCPHandler: Code: 57. DB::Exception: Table test_3.dict_src already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:43:11.977898 [ 3554 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:12.316384 [ 3475 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:12.421079 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:12.430443 [ 3470 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:12.430451 [ 3460 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:12.436614 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:12.507385 [ 3450 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:12.512270 [ 2903 ] {ab724a91-5160-4f68-ad60-c02aa82c9758} executeQuery: Code: 387. DB::Exception: Dictionary test_3.dict1 already exists. (DICTIONARY_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37242) (comment: 01160_table_dependencies.sh) (in query: CREATE DICTIONARY dict1 (`n` int DEFAULT 0, `m` int DEFAULT 1, `s` String DEFAULT 'qqq') PRIMARY KEY n SOURCE(CLICKHOUSE(HOST 'localhost' PORT tcpPort() USER 'default' TABLE 'dict_src' PASSWORD '[HIDDEN]' DB 'test_3')) LIFETIME(MIN 1 MAX 10) 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1614: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb1a3 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:43:12.515070 [ 2903 ] {ab724a91-5160-4f68-ad60-c02aa82c9758} TCPHandler: Code: 387. DB::Exception: Dictionary test_3.dict1 already exists. (DICTIONARY_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1614: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb1a3 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:43:12.715412 [ 3397 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:12.753268 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:12.978649 [ 3327 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:13.317161 [ 3256 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:13.431222 [ 3237 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:13.431250 [ 3239 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:13.472155 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:13.508287 [ 3220 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:13.510421 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:13.716619 [ 3167 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:13.796129 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:13.912145 [ 3933 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x00000000315a10ad 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159da2f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b6b4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa269fb 10. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:13.979564 [ 3094 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:14.316423 [ 3933 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x00000000315a10ad 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159da2f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b6b4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa269fb 10. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:14.317840 [ 3528 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:14.432086 [ 3518 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:14.432087 [ 3514 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:14.509140 [ 3503 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:14.566613 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:14.590247 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:14.717704 [ 3468 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:14.839635 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:14.981107 [ 3401 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:15.318609 [ 3323 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:15.432833 [ 3301 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:15.432843 [ 3306 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:15.510162 [ 3297 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:15.713136 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:15.718590 [ 3272 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:15.730326 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:15.982147 [ 3226 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:16.041307 [ 2904 ] {ca1f680a-1ab0-461e-834e-5cded68a93e7} executeQuery: Code: 36. DB::Exception: Dictionary (`test_3.dict1`) not found: While processing _CAST(dictGet('test_3.dict1', 'm', CAST('42', 'UInt64')) AS m_tmp_alter17495048188961782772, 'Int32') AS m: default expression and column type are incompatible. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37256) (comment: 01160_table_dependencies.sh) (in query: create table join(n int, m int default dictGet('test_3.dict1', 'm', 42::UInt64)) engine=Join(any, left, n);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:164: DB::ExternalDictionariesLoader::resolveDictionaryName(String const&, String const&) const @ 0x0000000034793e93 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::ExternalDictionariesLoader::getDictionaryStructure(String const&, std::shared_ptr) const @ 0x0000000034795416 6. DB::FunctionDictHelper::getDictionaryStructure(String const&) const @ 0x00000000096bcb67 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::getReturnTypeImpl(std::vector> const&) const @ 0x00000000096aca5d 8. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083d29bf 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60aa37 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b609cba 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60b9ac 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:253: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x0000000033224571 13. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000033b1870d 14. ./contrib/llvm-project/libcxx/include/string:1499: DB::ActionsMatcher::Data::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000033b3d553 15. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b20248 16. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b1a2f5 17. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b2182b 18. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b1a2f5 19. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000033af7075 20. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000033a7619f 21. ./contrib/llvm-project/libcxx/include/string:1499: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x0000000033aa9f33 22. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x0000000033aaabd2 23. ./build_docker/./src/Storages/ColumnsDescription.cpp:986: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000380ffc91 24. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000348a82f8 25. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348af396 26. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cde07 27. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:43:16.060216 [ 2904 ] {ca1f680a-1ab0-461e-834e-5cded68a93e7} TCPHandler: Code: 36. DB::Exception: Dictionary (`test_3.dict1`) not found: While processing _CAST(dictGet('test_3.dict1', 'm', CAST('42', 'UInt64')) AS m_tmp_alter17495048188961782772, 'Int32') AS m: default expression and column type are incompatible. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:164: DB::ExternalDictionariesLoader::resolveDictionaryName(String const&, String const&) const @ 0x0000000034793e93 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::ExternalDictionariesLoader::getDictionaryStructure(String const&, std::shared_ptr) const @ 0x0000000034795416 6. DB::FunctionDictHelper::getDictionaryStructure(String const&) const @ 0x00000000096bcb67 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::getReturnTypeImpl(std::vector> const&) const @ 0x00000000096aca5d 8. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083d29bf 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60aa37 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b609cba 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60b9ac 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:253: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x0000000033224571 13. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000033b1870d 14. ./contrib/llvm-project/libcxx/include/string:1499: DB::ActionsMatcher::Data::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000033b3d553 15. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b20248 16. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b1a2f5 17. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b2182b 18. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b1a2f5 19. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000033af7075 20. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000033a7619f 21. ./contrib/llvm-project/libcxx/include/string:1499: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x0000000033aa9f33 22. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x0000000033aaabd2 23. ./build_docker/./src/Storages/ColumnsDescription.cpp:986: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000380ffc91 24. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000348a82f8 25. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348af396 26. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cde07 27. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:43:16.319604 [ 3177 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:16.359182 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:16.433740 [ 3170 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:16.433904 [ 3178 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:16.511257 [ 3145 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:16.719320 [ 3071 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:16.761255 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:16.788075 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:16.982924 [ 3561 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:17.320566 [ 3468 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:17.406475 [ 3933 ] {ab2c5a6f-d09a-4b24-85cb-9f430e1ad8fb} executeQuery: Code: 57. DB::Exception: Table test_3.s already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44246) (comment: 01160_table_dependencies.sh) (in query: create table s (x default joinGet(test_3.join, 'm', 42::int)) engine=Set), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:43:17.409175 [ 3933 ] {ab2c5a6f-d09a-4b24-85cb-9f430e1ad8fb} TCPHandler: Code: 57. DB::Exception: Table test_3.s already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:43:17.432102 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:17.434652 [ 3445 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:17.434658 [ 3446 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:17.512614 [ 3451 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:17.720361 [ 3389 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:17.832427 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:17.893396 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:18.059490 [ 3933 ] {c707348a-cb49-47b5-a359-79ed3fbf2c1c} executeQuery: Code: 36. DB::Exception: Dictionary (`test_3.dict1`) not found: While processing _CAST(dictGet(test_3.dict1, 's', CAST('42', 'UInt64')) AS s_tmp_alter8229183709986750259, 'String') AS s: default expression and column type are incompatible. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44292) (comment: 01160_table_dependencies.sh) (in query: CREATE TABLE t (`n` int, `m` int DEFAULT joinGet(test_3.join, 'm', CAST('42', 'int')), `s` String DEFAULT dictGet(test_3.dict1, 's', CAST('42', 'UInt64')), `y` DEFAULT dictGet(test_3.dict2, 'm', CAST('42', 'UInt64'))) ENGINE = MergeTree ORDER BY n SETTINGS index_granularity = 40454, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189646301, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 10572573, merge_max_block_size = 5323, old_parts_lifetime = 36., prefer_fetch_merged_part_size_threshold = 1927278932, vertical_merge_algorithm_min_rows_to_activate = 682673, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 2370475839, index_granularity_bytes = 3326880, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 60501, primary_key_compress_block_size = 80459), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:164: DB::ExternalDictionariesLoader::resolveDictionaryName(String const&, String const&) const @ 0x0000000034793e93 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::ExternalDictionariesLoader::getDictionaryStructure(String const&, std::shared_ptr) const @ 0x0000000034795416 6. DB::FunctionDictHelper::getDictionaryStructure(String const&) const @ 0x00000000096bcb67 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::getReturnTypeImpl(std::vector> const&) const @ 0x00000000096aca5d 8. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083d29bf 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60aa37 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b609cba 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60b9ac 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:253: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x0000000033224571 13. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000033b1870d 14. ./contrib/llvm-project/libcxx/include/string:1499: DB::ActionsMatcher::Data::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000033b3d553 15. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b20248 16. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b1a2f5 17. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b2182b 18. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b1a2f5 19. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000033af7075 20. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000033a7619f 21. ./contrib/llvm-project/libcxx/include/string:1499: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x0000000033aa9f33 22. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x0000000033aaabd2 23. ./build_docker/./src/Storages/ColumnsDescription.cpp:986: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000380ffc91 24. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000348a82f8 25. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348af396 26. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cde07 27. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:43:18.063004 [ 3350 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:18.063614 [ 3933 ] {c707348a-cb49-47b5-a359-79ed3fbf2c1c} TCPHandler: Code: 36. DB::Exception: Dictionary (`test_3.dict1`) not found: While processing _CAST(dictGet(test_3.dict1, 's', CAST('42', 'UInt64')) AS s_tmp_alter8229183709986750259, 'String') AS s: default expression and column type are incompatible. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:164: DB::ExternalDictionariesLoader::resolveDictionaryName(String const&, String const&) const @ 0x0000000034793e93 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::ExternalDictionariesLoader::getDictionaryStructure(String const&, std::shared_ptr) const @ 0x0000000034795416 6. DB::FunctionDictHelper::getDictionaryStructure(String const&) const @ 0x00000000096bcb67 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::getReturnTypeImpl(std::vector> const&) const @ 0x00000000096aca5d 8. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083d29bf 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60aa37 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b609cba 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60b9ac 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:253: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x0000000033224571 13. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000033b1870d 14. ./contrib/llvm-project/libcxx/include/string:1499: DB::ActionsMatcher::Data::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000033b3d553 15. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b20248 16. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b1a2f5 17. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b2182b 18. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000033b1a2f5 19. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000033af7075 20. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000033a7619f 21. ./contrib/llvm-project/libcxx/include/string:1499: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x0000000033aa9f33 22. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x0000000033aaabd2 23. ./build_docker/./src/Storages/ColumnsDescription.cpp:986: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000380ffc91 24. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000348a82f8 25. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348af396 26. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cde07 27. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:43:18.321234 [ 3281 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:18.435494 [ 3246 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:18.435911 [ 3248 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:18.496487 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:18.513513 [ 3244 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:18.721203 [ 3139 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:18.740388 [ 3933 ] {c810b33b-3e80-4481-ac30-c9ee9aef7c29} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=748). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44310) (comment: 01160_table_dependencies.sh) (in query: select table, arraySort(dependencies_table), arraySort(loading_dependencies_table), arraySort(loading_dependent_table) from system.tables where database=currentDatabase() order by table), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:43:18.744191 [ 3933 ] {c810b33b-3e80-4481-ac30-c9ee9aef7c29} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=748). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:43:18.900977 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:18.954205 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:19.063908 [ 3236 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:19.321937 [ 3505 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:19.436520 [ 3478 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:19.436931 [ 3490 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:19.514328 [ 3456 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:19.625347 [ 3657 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {959c1387-6a29-41af-9a70-593d11e44aac::202510_1_87_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 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) @ 0x0000000039c89948 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000003999bfb7 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 @ 0x00000000399942f0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000039d15c04 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&) @ 0x0000000039d20399 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) @ 0x0000000039d1c606 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000396308a4 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x00000000396235dd 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000003963b3e0 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x00000000396504a0 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3c455d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:19.638452 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:19.722023 [ 3426 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:19.926051 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:19.998555 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:20.064696 [ 3359 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:20.067465 [ 3933 ] {7a32c888-a66d-45cc-8fcd-1b99e1a9fcd6} executeQuery: Code: 60. DB::Exception: Could not find table: t. (UNKNOWN_TABLE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44364) (comment: 01160_table_dependencies.sh) (in query: alter table t add column x int default in(1, test_3.s), drop column y), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000842350a 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034869c28 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003485e550 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 2025.10.23 23:43:20.070477 [ 3933 ] {7a32c888-a66d-45cc-8fcd-1b99e1a9fcd6} TCPHandler: Code: 60. DB::Exception: Could not find table: t. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000842350a 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034869c28 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003485e550 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 2025.10.23 23:43:20.322698 [ 3303 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:20.437440 [ 3272 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:20.437759 [ 3273 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:20.515631 [ 3263 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:20.721883 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:20.722904 [ 3253 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:20.945483 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:21.065526 [ 3226 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:21.066235 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:21.323681 [ 3194 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:21.438523 [ 3182 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:21.438612 [ 3175 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:21.602810 [ 3149 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:21.724314 [ 3134 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:21.810300 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:21.995129 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:22.066567 [ 3069 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:22.154772 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:22.324718 [ 3534 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:22.439642 [ 3535 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:22.440089 [ 3527 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:22.604093 [ 3506 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:22.725118 [ 3498 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:22.763116 [ 3933 ] {f6b485af-7e67-4b2f-a250-5a6709252ee6} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test_3.t' in scope SELECT n AS x FROM test_3.t WHERE n IN (SELECT n FROM test_3.join). (UNKNOWN_TABLE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44376) (comment: 01160_table_dependencies.sh) (in query: create materialized view mv to s as select n as x from t where n in (select n from 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa0996d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334eae8a 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003343676d 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf53bf 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348b2166 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cde07 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:43:22.767902 [ 3933 ] {f6b485af-7e67-4b2f-a250-5a6709252ee6} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test_3.t' in scope SELECT n AS x FROM test_3.t WHERE n IN (SELECT n FROM test_3.join). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa0996d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334eae8a 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003343676d 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf53bf 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348b2166 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cde07 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:43:22.884169 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:23.067453 [ 3423 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:23.091046 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:23.227000 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:23.325862 [ 3390 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:23.440863 [ 3379 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:23.441199 [ 3374 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:23.604902 [ 3333 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:23.726045 [ 3311 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:23.947158 [ 9453 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x00000000315a10ad 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159da2f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b6b4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa269fb 10. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:23.953855 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:24.068167 [ 3233 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:24.184740 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:24.212544 [ 4841 ] {4d9af187-fc70-4da8-bb45-04ceb1783493} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44484) (comment: 01160_table_dependencies.sh) (in query: detach database test_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000003494763c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:43:24.216499 [ 4841 ] {4d9af187-fc70-4da8-bb45-04ceb1783493} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000003494763c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:43:24.286055 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:24.327046 [ 3073 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:24.346152 [ 9453 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x00000000315a10ad 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159da2f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b6b4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa269fb 10. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:24.442087 [ 3562 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:24.442113 [ 3098 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:24.605702 [ 3410 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:24.726984 [ 3263 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:24.830709 [ 2903 ] {d2054d5a-5ea6-40ad-b102-cb065ec5370f} executeQuery: Code: 82. DB::Exception: Database test_3 already exists. (DATABASE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44514) (comment: 01160_table_dependencies.sh) (in query: attach database test_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000842350a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:147: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000348979e7 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 2025.10.23 23:43:24.841729 [ 2903 ] {d2054d5a-5ea6-40ad-b102-cb065ec5370f} TCPHandler: Code: 82. DB::Exception: Database test_3 already exists. (DATABASE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000842350a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:147: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000348979e7 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 2025.10.23 23:43:25.069128 [ 3544 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:25.093751 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:25.327596 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:25.328525 [ 3449 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:25.332862 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:25.443396 [ 3375 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:25.443403 [ 3378 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:25.606630 [ 3138 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:25.728299 [ 3133 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:26.070062 [ 3116 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:26.204942 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:26.329289 [ 3123 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:26.397923 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:26.430326 [ 2903 ] {346af166-9f01-4de1-b0dc-d82f134b995f} TablesLoader: Tables test_3.dist_01247 depend on default.number, but seems like that does not exist. Will ignore it and try to load existing tables 2025.10.23 23:43:26.444475 [ 3115 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:26.444475 [ 3125 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:26.483098 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:26.607400 [ 3106 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:26.734105 [ 3089 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:27.070659 [ 3531 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:27.270946 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:27.329997 [ 3457 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:27.445400 [ 3431 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:27.445520 [ 3434 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:27.470228 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:27.552716 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:27.648396 [ 3383 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:27.735116 [ 3361 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:28.071526 [ 3288 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:28.271642 [ 4841 ] {fadd174e-5982-45be-9aaf-0709098da0ec} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:51512) (comment: 01160_table_dependencies.sh) (in query: detach database test_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000003494763c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:43:28.274979 [ 4841 ] {fadd174e-5982-45be-9aaf-0709098da0ec} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000003494763c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:43:28.330632 [ 3218 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:28.337438 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:28.446224 [ 3208 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:28.446661 [ 3193 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:28.571652 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:28.610582 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:28.649095 [ 3144 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:28.736050 [ 3137 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:28.896208 [ 2903 ] {25526f9a-b479-4205-9b97-518324578d8b} executeQuery: Code: 82. DB::Exception: Database test_3 already exists. (DATABASE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:51558) (comment: 01160_table_dependencies.sh) (in query: attach database test_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000842350a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:147: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000348979e7 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 2025.10.23 23:43:28.898550 [ 2903 ] {25526f9a-b479-4205-9b97-518324578d8b} TCPHandler: Code: 82. DB::Exception: Database test_3 already exists. (DATABASE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000842350a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:147: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000348979e7 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 2025.10.23 23:43:29.072587 [ 3418 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:29.331352 [ 3074 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:29.412867 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:29.447230 [ 3518 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:29.447599 [ 3515 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:29.604286 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:29.649996 [ 3463 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:29.657323 [ 4841 ] {69333954-d564-486f-bfc5-61ced1b0ceb7} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:51564) (comment: 01160_table_dependencies.sh) (in query: detach database test_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000003494763c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:43:29.659569 [ 4841 ] {69333954-d564-486f-bfc5-61ced1b0ceb7} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000003494763c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:43:29.687924 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:29.736762 [ 3420 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:30.073640 [ 3385 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:30.332440 [ 3355 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:30.347836 [ 4841 ] {e09616a3-95c7-4609-bbf7-d62562972ba6} executeQuery: Code: 82. DB::Exception: Database test_3 already exists. (DATABASE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:51606) (comment: 01160_table_dependencies.sh) (in query: attach database test_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000842350a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:147: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000348979e7 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 2025.10.23 23:43:30.350221 [ 4841 ] {e09616a3-95c7-4609-bbf7-d62562972ba6} TCPHandler: Code: 82. DB::Exception: Database test_3 already exists. (DATABASE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000842350a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:147: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000348979e7 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 2025.10.23 23:43:30.448091 [ 3309 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:30.448573 [ 3306 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:30.650928 [ 3268 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:30.666973 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:30.729601 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:30.737530 [ 3220 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:30.979638 [ 4841 ] {accd4631-3773-4eb5-8943-9526b268a54a} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=5). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:51642) (comment: 01160_table_dependencies.sh) (in query: detach database test_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000003494763c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:43:30.982209 [ 4841 ] {accd4631-3773-4eb5-8943-9526b268a54a} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=5). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000003494763c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:43:31.074532 [ 3108 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:31.333189 [ 3084 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:31.448933 [ 3435 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:31.449596 [ 3345 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:31.622360 [ 4841 ] {00d5a322-71aa-47e1-91e7-87a53f6e97f2} executeQuery: Code: 82. DB::Exception: Database test_3 already exists. (DATABASE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:51646) (comment: 01160_table_dependencies.sh) (in query: attach database test_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000842350a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:147: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000348979e7 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 2025.10.23 23:43:31.624694 [ 4841 ] {00d5a322-71aa-47e1-91e7-87a53f6e97f2} TCPHandler: Code: 82. DB::Exception: Database test_3 already exists. (DATABASE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000842350a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:147: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000348979e7 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 2025.10.23 23:43:31.651593 [ 3518 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:31.720412 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:31.738246 [ 3484 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:31.765272 [ 3482 ] {} test_3.`02691_drop_column_replicated` (1045b1a8-f37f-4f75-892a-b44e770b298b): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_3/test/02691_drop_column/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:31.782154 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:32.075438 [ 3426 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:32.241652 [ 4841 ] {c1aa40fc-8d03-439f-a984-796526e7cc21} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=3). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:51674) (comment: 01160_table_dependencies.sh) (in query: detach database test_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000003494763c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:43:32.244021 [ 4841 ] {c1aa40fc-8d03-439f-a984-796526e7cc21} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000003494763c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:43:32.333910 [ 3379 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:32.366315 [ 2903 ] {644a454c-deba-47e4-969b-1c183c30920f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=748). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:51600) (comment: 00916_join_using_duplicate_columns.sql) (in query: SELECT * FROM (SELECT 1 AS x) AS t1 ALL RIGHT JOIN (SELECT 1 AS x) AS t2 ON t1.x = t2.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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:43:32.370470 [ 2903 ] {644a454c-deba-47e4-969b-1c183c30920f} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=748). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:43:32.450093 [ 3326 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:32.450727 [ 3325 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:32.652453 [ 3261 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:32.725786 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:32.739018 [ 3240 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:32.766010 [ 3244 ] {} test_3.`02691_drop_column_replicated` (1045b1a8-f37f-4f75-892a-b44e770b298b): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_3/test/02691_drop_column/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:32.827107 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:32.898578 [ 7652 ] {474ded7e-a01e-4ed3-9571-d11c572f85b3} executeQuery: Code: 82. DB::Exception: Database test_3 already exists. (DATABASE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:51690) (comment: 01160_table_dependencies.sh) (in query: attach database test_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000842350a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:147: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000348979e7 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 2025.10.23 23:43:32.901350 [ 7652 ] {474ded7e-a01e-4ed3-9571-d11c572f85b3} TCPHandler: Code: 82. DB::Exception: Database test_3 already exists. (DATABASE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000842350a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:147: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000348979e7 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 2025.10.23 23:43:33.076446 [ 3145 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:33.334691 [ 3060 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:33.451093 [ 3527 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:33.451579 [ 3074 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:33.521487 [ 7652 ] {cf28ca63-43b0-4393-8d07-ee95f6158474} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:51708) (comment: 01160_table_dependencies.sh) (in query: detach database test_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000003494763c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:43:33.525390 [ 7652 ] {cf28ca63-43b0-4393-8d07-ee95f6158474} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000003494763c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:43:33.653338 [ 3509 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:33.714622 [ 9453 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x00000000315a10ad 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159da2f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b6b4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa269fb 10. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:33.740050 [ 3496 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:33.759159 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:33.766820 [ 3487 ] {} test_3.`02691_drop_column_replicated` (1045b1a8-f37f-4f75-892a-b44e770b298b): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_3/test/02691_drop_column/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:33.868593 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:34.077475 [ 3419 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:34.242940 [ 7652 ] {89099c31-0d6f-403c-a3ac-635ef29fd5e5} executeQuery: Code: 82. DB::Exception: Database test_3 already exists. (DATABASE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:51742) (comment: 01160_table_dependencies.sh) (in query: attach database test_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000842350a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:147: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000348979e7 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 2025.10.23 23:43:34.245391 [ 7652 ] {89099c31-0d6f-403c-a3ac-635ef29fd5e5} TCPHandler: Code: 82. DB::Exception: Database test_3 already exists. (DATABASE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000842350a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:147: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000348979e7 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 2025.10.23 23:43:34.335776 [ 3377 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:34.452165 [ 3344 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:34.452419 [ 3365 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:34.654327 [ 3298 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:34.741076 [ 3295 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:34.767662 [ 3290 ] {} test_3.`02691_drop_column_replicated` (1045b1a8-f37f-4f75-892a-b44e770b298b): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_3/test/02691_drop_column/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:34.853134 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:34.902472 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:35.078539 [ 3084 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:35.337039 [ 3062 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:35.453397 [ 3068 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:35.453391 [ 3069 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:35.564654 [ 4841 ] {2ec02585-0e2a-43ff-aa48-b32b4e412680} DB::ConcurrentHashJoin::ConcurrentHashJoin(ContextPtr, std::shared_ptr, size_t, const Block &, const StatsCollectingParams &, bool): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202dea34 6. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:0: DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, std::shared_ptr, unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool) @ 0x0000000034775418 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr&, std::shared_ptr&, DB::SettingFieldMaxThreads const&, DB::Block const&, DB::StatsCollectingParams&, void>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::SettingFieldMaxThreads const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x0000000034df93df 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000034debf55 9. ./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&) @ 0x0000000034d95d85 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d6a797 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0b8de 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cfd8b2 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034cf6172 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5bf1 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:35.572782 [ 4841 ] {2ec02585-0e2a-43ff-aa48-b32b4e412680} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:51704) (comment: 02373_analyzer_join_use_nulls.sql) (in query: -- { echoOn } SELECT t1.id AS t1_id, toTypeName(t1_id), t1.value AS t1_value, toTypeName(t1_value), t2.id AS t2_id, toTypeName(t2_id), t2.value AS t2_value, toTypeName(t2_value) FROM test_table_join_1 AS t1 INNER JOIN test_table_join_2 AS t2 ON t1.id = t2.id 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202dea34 6. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:0: DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, std::shared_ptr, unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool) @ 0x0000000034775418 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr&, std::shared_ptr&, DB::SettingFieldMaxThreads const&, DB::Block const&, DB::StatsCollectingParams&, void>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::SettingFieldMaxThreads const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x0000000034df93df 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000034debf55 9. ./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&) @ 0x0000000034d95d85 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d6a797 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0b8de 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cfd8b2 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034cf6172 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5bf1 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 2025.10.23 23:43:35.576532 [ 4841 ] {2ec02585-0e2a-43ff-aa48-b32b4e412680} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202dea34 6. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:0: DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, std::shared_ptr, unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool) @ 0x0000000034775418 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr&, std::shared_ptr&, DB::SettingFieldMaxThreads const&, DB::Block const&, DB::StatsCollectingParams&, void>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::SettingFieldMaxThreads const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x0000000034df93df 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000034debf55 9. ./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&) @ 0x0000000034d95d85 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d6a797 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0b8de 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cfd8b2 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034cf6172 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5bf1 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 2025.10.23 23:43:35.655600 [ 3056 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:35.742051 [ 3055 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:35.968548 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:36.079448 [ 3060 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:36.088230 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:36.338174 [ 3391 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:36.342770 [ 7652 ] {430667a8-06f2-431c-909e-eedd2445552d} TablesLoader: Tables test_3.dist_01247 depend on default.number, but seems like that does not exist. Will ignore it and try to load existing tables 2025.10.23 23:43:36.454425 [ 3329 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:36.454568 [ 3418 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:36.518541 [ 22120 ] {} void DB::AsyncLoader::worker(Pool &): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=6, jobs=6): Cannot attach table `test_3`.`unhex_in_fix_string_table` from metadata file /var/lib/clickhouse/store/72e/72e8cccc-d01c-48de-9c15-1f652f3a0118/unhex_in_fix_string_table.sql from query ATTACH TABLE test_3.unhex_in_fix_string_table UUID '3b655193-aba4-4bd0-bece-9ef742b1b1fb' (`dt` Date, `s1` FixedString(20), `s2` String) ENGINE = MergeTree PARTITION BY dt ORDER BY tuple() SETTINGS index_granularity = 64698, min_bytes_for_wide_part = 138054863, 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 = 64607479, compact_parts_max_bytes_to_buffer = 292899815, compact_parts_max_granules_to_buffer = 164, compact_parts_merge_max_bytes_to_prefetch_part = 27406253, merge_max_block_size = 14977, old_parts_lifetime = 291., 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 = 3234689053, index_granularity_bytes = 20210295, concurrent_part_removal_threshold = 73, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 52622, primary_key_compress_block_size = 81127. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataPartsFromDisk(std::vector, std::allocator>>&) @ 0x0000000039704427 8. ./contrib/llvm-project/libcxx/include/vector:1454: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x000000003970c533 9. ./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>) @ 0x000000003a2e5f4a 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a2e404f 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2d3063 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7b27a 13. ./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 @ 0x0000000038308626 14. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:0: DB::createTableFromAST(DB::ASTCreateQuery, String const&, String const&, std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000003294a31d 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::DatabaseOrdinary::loadTableFromMetadata(std::shared_ptr, String const&, DB::QualifiedTableName const&, std::shared_ptr const&, DB::LoadingStrictnessLevel) @ 0x00000000329c9071 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000329e2adb 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000207110e6 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000020712b00 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 22. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:36.657154 [ 3296 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:36.742914 [ 3213 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:36.781477 [ 7652 ] {430667a8-06f2-431c-909e-eedd2445552d} executeQuery: Code: 722. DB::Exception: Waited job failed: Code: 695. DB::Exception: Load job 'load table test_3.unhex_in_fix_string_table' failed: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=6, jobs=6): Cannot attach table `test_3`.`unhex_in_fix_string_table` from metadata file /var/lib/clickhouse/store/72e/72e8cccc-d01c-48de-9c15-1f652f3a0118/unhex_in_fix_string_table.sql from query ATTACH TABLE test_3.unhex_in_fix_string_table UUID '3b655193-aba4-4bd0-bece-9ef742b1b1fb' (`dt` Date, `s1` FixedString(20), `s2` String) ENGINE = MergeTree PARTITION BY dt ORDER BY tuple() SETTINGS index_granularity = 64698, min_bytes_for_wide_part = 138054863, 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 = 64607479, compact_parts_max_bytes_to_buffer = 292899815, compact_parts_max_granules_to_buffer = 164, compact_parts_merge_max_bytes_to_prefetch_part = 27406253, merge_max_block_size = 14977, old_parts_lifetime = 291., 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 = 3234689053, index_granularity_bytes = 20210295, concurrent_part_removal_threshold = 73, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 52622, primary_key_compress_block_size = 81127. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataPartsFromDisk(std::vector, std::allocator>>&) @ 0x0000000039704427 8. ./contrib/llvm-project/libcxx/include/vector:1454: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x000000003970c533 9. ./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>) @ 0x000000003a2e5f4a 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a2e404f 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2d3063 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7b27a 13. ./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 @ 0x0000000038308626 14. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:0: DB::createTableFromAST(DB::ASTCreateQuery, String const&, String const&, std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000003294a31d 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::DatabaseOrdinary::loadTableFromMetadata(std::shared_ptr, String const&, DB::QualifiedTableName const&, std::shared_ptr const&, DB::LoadingStrictnessLevel) @ 0x00000000329c9071 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000329e2adb 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000207110e6 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000020712b00 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 22. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)). (ASYNC_LOAD_FAILED) (version 24.8.14.10542.altinitytest (altinity build)). (ASYNC_LOAD_WAIT_FAILED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:60028) (comment: 01160_table_dependencies.sh) (in query: attach database test_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Common/AsyncLoader.cpp:444: DB::AsyncLoader::wait(std::shared_ptr const&, bool) @ 0x0000000020706a5b 5. ./src/Common/AsyncLoader.h:547: DB::waitLoad(unsigned long, std::vector, std::allocator>> const&, bool) @ 0x000000002065a61b 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:369: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000348954b3 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:43:36.784327 [ 7652 ] {430667a8-06f2-431c-909e-eedd2445552d} TCPHandler: Code: 722. DB::Exception: Waited job failed: Code: 695. DB::Exception: Load job 'load table test_3.unhex_in_fix_string_table' failed: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=6, jobs=6): Cannot attach table `test_3`.`unhex_in_fix_string_table` from metadata file /var/lib/clickhouse/store/72e/72e8cccc-d01c-48de-9c15-1f652f3a0118/unhex_in_fix_string_table.sql from query ATTACH TABLE test_3.unhex_in_fix_string_table UUID '3b655193-aba4-4bd0-bece-9ef742b1b1fb' (`dt` Date, `s1` FixedString(20), `s2` String) ENGINE = MergeTree PARTITION BY dt ORDER BY tuple() SETTINGS index_granularity = 64698, min_bytes_for_wide_part = 138054863, 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 = 64607479, compact_parts_max_bytes_to_buffer = 292899815, compact_parts_max_granules_to_buffer = 164, compact_parts_merge_max_bytes_to_prefetch_part = 27406253, merge_max_block_size = 14977, old_parts_lifetime = 291., 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 = 3234689053, index_granularity_bytes = 20210295, concurrent_part_removal_threshold = 73, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 52622, primary_key_compress_block_size = 81127. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataPartsFromDisk(std::vector, std::allocator>>&) @ 0x0000000039704427 8. ./contrib/llvm-project/libcxx/include/vector:1454: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x000000003970c533 9. ./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>) @ 0x000000003a2e5f4a 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a2e404f 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2d3063 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7b27a 13. ./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 @ 0x0000000038308626 14. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:0: DB::createTableFromAST(DB::ASTCreateQuery, String const&, String const&, std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000003294a31d 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::DatabaseOrdinary::loadTableFromMetadata(std::shared_ptr, String const&, DB::QualifiedTableName const&, std::shared_ptr const&, DB::LoadingStrictnessLevel) @ 0x00000000329c9071 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000329e2adb 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000207110e6 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000020712b00 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 22. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)). (ASYNC_LOAD_FAILED) (version 24.8.14.10542.altinitytest (altinity build)). (ASYNC_LOAD_WAIT_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Common/AsyncLoader.cpp:444: DB::AsyncLoader::wait(std::shared_ptr const&, bool) @ 0x0000000020706a5b 5. ./src/Common/AsyncLoader.h:547: DB::waitLoad(unsigned long, std::vector, std::allocator>> const&, bool) @ 0x000000002065a61b 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:369: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000348954b3 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:43:37.080470 [ 3063 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:37.104423 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:37.122817 [ 4675 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:37.339364 [ 3141 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:37.423367 [ 7652 ] {92cf2fb5-c937-4faf-90e7-1bf5f0a452cd} executeQuery: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:60056) (comment: 01160_table_dependencies.sh) (in query: detach database test_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:666: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x00000000339ae146 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000349459ff 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:37.427034 [ 7652 ] {92cf2fb5-c937-4faf-90e7-1bf5f0a452cd} TCPHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:666: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x00000000339ae146 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000349459ff 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:37.464678 [ 3174 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:37.464736 [ 3061 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:37.658013 [ 3098 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:37.743990 [ 3564 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:38.081481 [ 3111 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:38.176967 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:38.176955 [ 4675 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:38.340464 [ 3551 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:38.440726 [ 7652 ] {b94bce62-0f9c-42dc-950a-5e70a9ec08c9} TablesLoader: Tables test_3.dist_01247 depend on default.number, but seems like that does not exist. Will ignore it and try to load existing tables 2025.10.23 23:43:38.465691 [ 3550 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:38.466038 [ 3565 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:38.515586 [ 22126 ] {} void DB::AsyncLoader::worker(Pool &): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=4): Cannot attach table `test_3`.`table_00609` from metadata file /var/lib/clickhouse/store/72e/72e8cccc-d01c-48de-9c15-1f652f3a0118/table_00609.sql from query ATTACH TABLE test_3.table_00609 UUID '68453d5d-ab6d-4991-a02a-07cffc418701' (`key` UInt64, `val` UInt64, `def` UInt64 DEFAULT val + 1) ENGINE = MergeTree ORDER BY key SETTINGS index_granularity = 8192, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 49, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 400014129, compact_parts_max_granules_to_buffer = 234, compact_parts_merge_max_bytes_to_prefetch_part = 1105356, merge_max_block_size = 6169, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 22767327, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 52259, primary_key_compress_block_size = 8932. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataPartsFromDisk(std::vector, std::allocator>>&) @ 0x0000000039704427 8. ./contrib/llvm-project/libcxx/include/vector:1454: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x000000003970c533 9. ./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>) @ 0x000000003a2e5f4a 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a2e404f 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2d3063 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7b27a 13. ./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 @ 0x0000000038308626 14. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:0: DB::createTableFromAST(DB::ASTCreateQuery, String const&, String const&, std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000003294a31d 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::DatabaseOrdinary::loadTableFromMetadata(std::shared_ptr, String const&, DB::QualifiedTableName const&, std::shared_ptr const&, DB::LoadingStrictnessLevel) @ 0x00000000329c9071 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000329e2adb 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000207110e6 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000020712b00 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 22. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:38.530689 [ 22122 ] {} void DB::AsyncLoader::worker(Pool &): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=9): Cannot attach table `test_3`.`table1` from metadata file /var/lib/clickhouse/store/72e/72e8cccc-d01c-48de-9c15-1f652f3a0118/table1.sql from query ATTACH TABLE test_3.table1 UUID 'b8db3d6a-6199-4d9d-9ab7-f9a99f2d7089' (`id` Int64, `v` UInt64) ENGINE = ReplicatedReplacingMergeTree('/clickhouse/tables/test_3/test_table12', '1', v) PARTITION BY id % 200 ORDER BY id SETTINGS index_granularity = 15186, min_bytes_for_wide_part = 540145247, 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 = 120218567, compact_parts_max_granules_to_buffer = 204, compact_parts_merge_max_bytes_to_prefetch_part = 9143981, merge_max_block_size = 13263, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 868585, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 5776731, concurrent_part_removal_threshold = 5, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 75573, primary_key_compress_block_size = 44841. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataPartsFromDisk(std::vector, std::allocator>>&) @ 0x0000000039704427 8. ./contrib/llvm-project/libcxx/include/vector:1454: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x000000003970c533 9. ./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) @ 0x00000000386f45bc 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, void>(std::allocator const&, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003a2e359e 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2d2f53 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7b27a 13. ./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 @ 0x0000000038308626 14. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:0: DB::createTableFromAST(DB::ASTCreateQuery, String const&, String const&, std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000003294a31d 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::DatabaseOrdinary::loadTableFromMetadata(std::shared_ptr, String const&, DB::QualifiedTableName const&, std::shared_ptr const&, DB::LoadingStrictnessLevel) @ 0x00000000329c9071 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000329e2adb 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000207110e6 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000020712b00 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 22. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:38.630925 [ 22126 ] {} void DB::AsyncLoader::worker(Pool &): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0): Cannot attach table `test_3`.`n` from metadata file /var/lib/clickhouse/store/72e/72e8cccc-d01c-48de-9c15-1f652f3a0118/n.sql from query ATTACH TABLE test_3.n UUID '14a607e0-bfe4-4203-a862-e609f02c64fd' (`nc` Nullable(Int32)) ENGINE = MergeTree PARTITION BY nc ORDER BY tuple() SETTINGS allow_nullable_key = 1, index_granularity = 34430, min_bytes_for_wide_part = 565464583, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 52, min_bytes_for_full_part_storage = 199435806, compact_parts_max_bytes_to_buffer = 293221031, compact_parts_max_granules_to_buffer = 197, compact_parts_merge_max_bytes_to_prefetch_part = 10257876, merge_max_block_size = 9546, old_parts_lifetime = 421., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 408996, vertical_merge_algorithm_min_columns_to_activate = 2, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 5530322, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 76061, primary_key_compress_block_size = 9718. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataPartsFromDisk(std::vector, std::allocator>>&) @ 0x0000000039704427 8. ./contrib/llvm-project/libcxx/include/vector:1454: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x000000003970c533 9. ./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>) @ 0x000000003a2e5f4a 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a2e404f 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2d3063 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7b27a 13. ./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 @ 0x0000000038308626 14. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:0: DB::createTableFromAST(DB::ASTCreateQuery, String const&, String const&, std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000003294a31d 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::DatabaseOrdinary::loadTableFromMetadata(std::shared_ptr, String const&, DB::QualifiedTableName const&, std::shared_ptr const&, DB::LoadingStrictnessLevel) @ 0x00000000329c9071 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000329e2adb 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000207110e6 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000020712b00 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 22. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:38.658997 [ 3074 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:38.707531 [ 7652 ] {b94bce62-0f9c-42dc-950a-5e70a9ec08c9} executeQuery: Code: 722. DB::Exception: Waited job failed: Code: 695. DB::Exception: Load job 'load table test_3.table1' failed: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=9): Cannot attach table `test_3`.`table1` from metadata file /var/lib/clickhouse/store/72e/72e8cccc-d01c-48de-9c15-1f652f3a0118/table1.sql from query ATTACH TABLE test_3.table1 UUID 'b8db3d6a-6199-4d9d-9ab7-f9a99f2d7089' (`id` Int64, `v` UInt64) ENGINE = ReplicatedReplacingMergeTree('/clickhouse/tables/test_3/test_table12', '1', v) PARTITION BY id % 200 ORDER BY id SETTINGS index_granularity = 15186, min_bytes_for_wide_part = 540145247, 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 = 120218567, compact_parts_max_granules_to_buffer = 204, compact_parts_merge_max_bytes_to_prefetch_part = 9143981, merge_max_block_size = 13263, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 868585, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 5776731, concurrent_part_removal_threshold = 5, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 75573, primary_key_compress_block_size = 44841. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataPartsFromDisk(std::vector, std::allocator>>&) @ 0x0000000039704427 8. ./contrib/llvm-project/libcxx/include/vector:1454: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x000000003970c533 9. ./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) @ 0x00000000386f45bc 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, void>(std::allocator const&, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003a2e359e 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2d2f53 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7b27a 13. ./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 @ 0x0000000038308626 14. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:0: DB::createTableFromAST(DB::ASTCreateQuery, String const&, String const&, std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000003294a31d 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::DatabaseOrdinary::loadTableFromMetadata(std::shared_ptr, String const&, DB::QualifiedTableName const&, std::shared_ptr const&, DB::LoadingStrictnessLevel) @ 0x00000000329c9071 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000329e2adb 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000207110e6 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000020712b00 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 22. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)). (ASYNC_LOAD_FAILED) (version 24.8.14.10542.altinitytest (altinity build)). (ASYNC_LOAD_WAIT_FAILED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:60070) (comment: 01160_table_dependencies.sh) (in query: attach database test_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Common/AsyncLoader.cpp:444: DB::AsyncLoader::wait(std::shared_ptr const&, bool) @ 0x0000000020706a5b 5. ./src/Common/AsyncLoader.h:547: DB::waitLoad(unsigned long, std::vector, std::allocator>> const&, bool) @ 0x000000002065a61b 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:369: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000348954b3 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:43:38.712446 [ 7652 ] {b94bce62-0f9c-42dc-950a-5e70a9ec08c9} TCPHandler: Code: 722. DB::Exception: Waited job failed: Code: 695. DB::Exception: Load job 'load table test_3.table1' failed: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=9): Cannot attach table `test_3`.`table1` from metadata file /var/lib/clickhouse/store/72e/72e8cccc-d01c-48de-9c15-1f652f3a0118/table1.sql from query ATTACH TABLE test_3.table1 UUID 'b8db3d6a-6199-4d9d-9ab7-f9a99f2d7089' (`id` Int64, `v` UInt64) ENGINE = ReplicatedReplacingMergeTree('/clickhouse/tables/test_3/test_table12', '1', v) PARTITION BY id % 200 ORDER BY id SETTINGS index_granularity = 15186, min_bytes_for_wide_part = 540145247, 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 = 120218567, compact_parts_max_granules_to_buffer = 204, compact_parts_merge_max_bytes_to_prefetch_part = 9143981, merge_max_block_size = 13263, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 868585, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 5776731, concurrent_part_removal_threshold = 5, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 75573, primary_key_compress_block_size = 44841. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataPartsFromDisk(std::vector, std::allocator>>&) @ 0x0000000039704427 8. ./contrib/llvm-project/libcxx/include/vector:1454: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x000000003970c533 9. ./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) @ 0x00000000386f45bc 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, void>(std::allocator const&, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003a2e359e 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2d2f53 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7b27a 13. ./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 @ 0x0000000038308626 14. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:0: DB::createTableFromAST(DB::ASTCreateQuery, String const&, String const&, std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000003294a31d 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::DatabaseOrdinary::loadTableFromMetadata(std::shared_ptr, String const&, DB::QualifiedTableName const&, std::shared_ptr const&, DB::LoadingStrictnessLevel) @ 0x00000000329c9071 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000329e2adb 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000207110e6 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000020712b00 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 22. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)). (ASYNC_LOAD_FAILED) (version 24.8.14.10542.altinitytest (altinity build)). (ASYNC_LOAD_WAIT_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Common/AsyncLoader.cpp:444: DB::AsyncLoader::wait(std::shared_ptr const&, bool) @ 0x0000000020706a5b 5. ./src/Common/AsyncLoader.h:547: DB::waitLoad(unsigned long, std::vector, std::allocator>> const&, bool) @ 0x000000002065a61b 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:369: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000348954b3 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:43:38.744982 [ 3532 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:39.082276 [ 3546 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:39.213441 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:39.229686 [ 4675 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:39.338335 [ 7652 ] {a72fc2fe-bd5e-41cc-b429-0fe89dfdc812} executeQuery: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:60114) (comment: 01160_table_dependencies.sh) (in query: detach database test_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:666: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x00000000339ae146 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000349459ff 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:39.341281 [ 3516 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:39.341841 [ 7652 ] {a72fc2fe-bd5e-41cc-b429-0fe89dfdc812} TCPHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:666: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x00000000339ae146 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000349459ff 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:39.466558 [ 3515 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:39.467256 [ 3518 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:39.660318 [ 3511 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:39.746154 [ 3524 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:40.083066 [ 3500 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:40.210226 [ 7652 ] {292acfe8-0bec-4873-b245-8e7798b46772} TablesLoader: Tables test_3.dist_01247 depend on default.number, but seems like that does not exist. Will ignore it and try to load existing tables 2025.10.23 23:43:40.282942 [ 4675 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:40.300027 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:40.322819 [ 13714 ] {} void DB::AsyncLoader::worker(Pool &): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1): Cannot attach table `test_3`.`n` from metadata file /var/lib/clickhouse/store/72e/72e8cccc-d01c-48de-9c15-1f652f3a0118/n.sql from query ATTACH TABLE test_3.n UUID '14a607e0-bfe4-4203-a862-e609f02c64fd' (`nc` Nullable(Int32)) ENGINE = MergeTree PARTITION BY nc ORDER BY tuple() SETTINGS allow_nullable_key = 1, index_granularity = 34430, min_bytes_for_wide_part = 565464583, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 52, min_bytes_for_full_part_storage = 199435806, compact_parts_max_bytes_to_buffer = 293221031, compact_parts_max_granules_to_buffer = 197, compact_parts_merge_max_bytes_to_prefetch_part = 10257876, merge_max_block_size = 9546, old_parts_lifetime = 421., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 408996, vertical_merge_algorithm_min_columns_to_activate = 2, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 5530322, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 76061, primary_key_compress_block_size = 9718. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataPartsFromDisk(std::vector, std::allocator>>&) @ 0x0000000039704427 8. ./contrib/llvm-project/libcxx/include/vector:1454: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x000000003970c533 9. ./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>) @ 0x000000003a2e5f4a 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a2e404f 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2d3063 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7b27a 13. ./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 @ 0x0000000038308626 14. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:0: DB::createTableFromAST(DB::ASTCreateQuery, String const&, String const&, std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000003294a31d 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::DatabaseOrdinary::loadTableFromMetadata(std::shared_ptr, String const&, DB::QualifiedTableName const&, std::shared_ptr const&, DB::LoadingStrictnessLevel) @ 0x00000000329c9071 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000329e2adb 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000207110e6 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000020712b00 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 22. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:40.341969 [ 3496 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:40.467419 [ 3491 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:40.468648 [ 3485 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:40.661356 [ 3487 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:40.747525 [ 3482 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:40.815474 [ 7652 ] {292acfe8-0bec-4873-b245-8e7798b46772} executeQuery: Code: 722. DB::Exception: Waited job failed: Code: 695. DB::Exception: Load job 'load table test_3.n' failed: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1): Cannot attach table `test_3`.`n` from metadata file /var/lib/clickhouse/store/72e/72e8cccc-d01c-48de-9c15-1f652f3a0118/n.sql from query ATTACH TABLE test_3.n UUID '14a607e0-bfe4-4203-a862-e609f02c64fd' (`nc` Nullable(Int32)) ENGINE = MergeTree PARTITION BY nc ORDER BY tuple() SETTINGS allow_nullable_key = 1, index_granularity = 34430, min_bytes_for_wide_part = 565464583, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 52, min_bytes_for_full_part_storage = 199435806, compact_parts_max_bytes_to_buffer = 293221031, compact_parts_max_granules_to_buffer = 197, compact_parts_merge_max_bytes_to_prefetch_part = 10257876, merge_max_block_size = 9546, old_parts_lifetime = 421., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 408996, vertical_merge_algorithm_min_columns_to_activate = 2, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 5530322, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 76061, primary_key_compress_block_size = 9718. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataPartsFromDisk(std::vector, std::allocator>>&) @ 0x0000000039704427 8. ./contrib/llvm-project/libcxx/include/vector:1454: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x000000003970c533 9. ./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>) @ 0x000000003a2e5f4a 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a2e404f 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2d3063 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7b27a 13. ./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 @ 0x0000000038308626 14. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:0: DB::createTableFromAST(DB::ASTCreateQuery, String const&, String const&, std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000003294a31d 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::DatabaseOrdinary::loadTableFromMetadata(std::shared_ptr, String const&, DB::QualifiedTableName const&, std::shared_ptr const&, DB::LoadingStrictnessLevel) @ 0x00000000329c9071 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000329e2adb 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000207110e6 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000020712b00 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 22. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)). (ASYNC_LOAD_FAILED) (version 24.8.14.10542.altinitytest (altinity build)). (ASYNC_LOAD_WAIT_FAILED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:60124) (comment: 01160_table_dependencies.sh) (in query: attach database test_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Common/AsyncLoader.cpp:444: DB::AsyncLoader::wait(std::shared_ptr const&, bool) @ 0x0000000020706a5b 5. ./src/Common/AsyncLoader.h:547: DB::waitLoad(unsigned long, std::vector, std::allocator>> const&, bool) @ 0x000000002065a61b 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:369: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000348954b3 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:43:40.873473 [ 7652 ] {292acfe8-0bec-4873-b245-8e7798b46772} TCPHandler: Code: 722. DB::Exception: Waited job failed: Code: 695. DB::Exception: Load job 'load table test_3.n' failed: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1): Cannot attach table `test_3`.`n` from metadata file /var/lib/clickhouse/store/72e/72e8cccc-d01c-48de-9c15-1f652f3a0118/n.sql from query ATTACH TABLE test_3.n UUID '14a607e0-bfe4-4203-a862-e609f02c64fd' (`nc` Nullable(Int32)) ENGINE = MergeTree PARTITION BY nc ORDER BY tuple() SETTINGS allow_nullable_key = 1, index_granularity = 34430, min_bytes_for_wide_part = 565464583, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 52, min_bytes_for_full_part_storage = 199435806, compact_parts_max_bytes_to_buffer = 293221031, compact_parts_max_granules_to_buffer = 197, compact_parts_merge_max_bytes_to_prefetch_part = 10257876, merge_max_block_size = 9546, old_parts_lifetime = 421., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 408996, vertical_merge_algorithm_min_columns_to_activate = 2, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 5530322, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 76061, primary_key_compress_block_size = 9718. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataPartsFromDisk(std::vector, std::allocator>>&) @ 0x0000000039704427 8. ./contrib/llvm-project/libcxx/include/vector:1454: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x000000003970c533 9. ./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>) @ 0x000000003a2e5f4a 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a2e404f 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2d3063 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7b27a 13. ./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 @ 0x0000000038308626 14. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:0: DB::createTableFromAST(DB::ASTCreateQuery, String const&, String const&, std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000003294a31d 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::DatabaseOrdinary::loadTableFromMetadata(std::shared_ptr, String const&, DB::QualifiedTableName const&, std::shared_ptr const&, DB::LoadingStrictnessLevel) @ 0x00000000329c9071 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000329e2adb 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000207110e6 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000020712b00 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 22. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)). (ASYNC_LOAD_FAILED) (version 24.8.14.10542.altinitytest (altinity build)). (ASYNC_LOAD_WAIT_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Common/AsyncLoader.cpp:444: DB::AsyncLoader::wait(std::shared_ptr const&, bool) @ 0x0000000020706a5b 5. ./src/Common/AsyncLoader.h:547: DB::waitLoad(unsigned long, std::vector, std::allocator>> const&, bool) @ 0x000000002065a61b 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:369: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000348954b3 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:43:41.084215 [ 3479 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:41.342693 [ 3489 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:41.366462 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:41.397330 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:41.468875 [ 3467 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:41.469686 [ 3468 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:41.520444 [ 4841 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:41.563211 [ 7652 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:41.662396 [ 3463 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:41.748718 [ 3462 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:42.075985 [ 7652 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:42.085223 [ 3455 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:42.122017 [ 7652 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:42.344193 [ 3454 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:42.391625 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:42.470104 [ 3448 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:42.470633 [ 3439 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:42.625163 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:42.640217 [ 7652 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:42.663574 [ 3445 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:42.685129 [ 4841 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:42.749741 [ 3451 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:43.086436 [ 3533 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:43.194012 [ 4841 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:43.242048 [ 4841 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:43.345215 [ 3430 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:43.433380 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:43.471184 [ 3419 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:43.472146 [ 3422 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:43.664786 [ 3424 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:43.725157 [ 7652 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:43.731041 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:43.751276 [ 3412 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:43.773372 [ 4841 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:43.962932 [ 9453 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x00000000315a10ad 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159da2f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b6b4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa269fb 10. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:44.087620 [ 3414 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:44.261032 [ 4841 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:44.310128 [ 4841 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:44.346144 [ 3407 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:44.404213 [ 9453 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x00000000315a10ad 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159da2f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b6b4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa269fb 10. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:44.472608 [ 3405 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:44.473266 [ 3408 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:44.535525 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:44.665634 [ 3390 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:44.752666 [ 3384 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:44.835532 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:44.859953 [ 7652 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:44.905037 [ 4841 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:45.088765 [ 3394 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:45.346954 [ 3378 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:45.399489 [ 4841 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:45.463930 [ 4841 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:45.473929 [ 3369 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:45.474328 [ 3375 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:45.587546 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:45.666587 [ 3379 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:45.753636 [ 3376 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:45.929005 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:46.021075 [ 4841 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:46.069587 [ 4841 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:46.089623 [ 3357 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:46.420991 [ 3340 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:46.474960 [ 3353 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:46.475467 [ 3343 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:46.569750 [ 4841 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:46.614958 [ 4841 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:46.638504 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:46.667509 [ 3339 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:46.754578 [ 3344 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:47.023815 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:47.090452 [ 3328 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:47.121662 [ 4841 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:47.178975 [ 4841 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:47.422094 [ 3333 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:47.476564 [ 3335 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:47.477469 [ 3341 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:47.668773 [ 3331 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:47.680062 [ 7652 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:47.715528 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:47.729162 [ 7652 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:47.755915 [ 3318 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:48.091591 [ 3307 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:48.157997 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:48.228366 [ 4841 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:48.262352 [ 4841 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:48.423240 [ 3304 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:48.477969 [ 3305 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:48.478813 [ 3313 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:48.669967 [ 3303 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:48.729264 [ 7652 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:48.756876 [ 3302 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:48.775219 [ 7652 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:48.857121 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:49.092791 [ 3293 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:49.228058 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:49.297153 [ 4841 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:49.424495 [ 3278 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:49.479226 [ 3283 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:49.480212 [ 3280 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:49.541400 [ 4841 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:49.671120 [ 3279 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:49.757935 [ 3281 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:49.904777 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:50.024954 [ 4841 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:50.073543 [ 4841 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:50.093832 [ 3269 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:50.288998 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:50.425512 [ 3261 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:50.480706 [ 3257 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:50.481307 [ 3264 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:50.577126 [ 4841 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:50.624104 [ 4841 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:50.672281 [ 3255 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:50.758948 [ 3250 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:50.951107 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:51.094901 [ 3254 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:51.278953 [ 4841 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:51.293256 [ 7652 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:51.373449 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:51.426840 [ 3258 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:51.482038 [ 3244 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:51.482282 [ 3245 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:51.673606 [ 3235 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:51.760270 [ 3233 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:51.812177 [ 4841 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:51.857460 [ 4841 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:52.010293 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:52.096244 [ 3241 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:52.408262 [ 4841 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:52.428126 [ 3229 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:52.433065 [ 4841 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:52.436157 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:52.483208 [ 3218 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:52.483219 [ 3222 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:52.674829 [ 3221 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:52.761335 [ 3210 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:53.010313 [ 4841 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:53.039404 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:53.064260 [ 4675 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:53.097259 [ 3209 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:53.429009 [ 3208 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:53.482567 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:53.484230 [ 3194 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:53.484749 [ 3194 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:53.546490 [ 7652 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:53.589549 [ 7652 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:53.675970 [ 3191 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:53.762313 [ 3188 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:54.072546 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:54.074661 [ 4675 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:54.098202 [ 3180 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:54.215422 [ 7652 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:54.429864 [ 3177 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:54.485047 [ 3171 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:54.485775 [ 3170 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:54.547398 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:54.676717 [ 3163 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:54.713233 [ 7652 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:54.757254 [ 7652 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:54.763271 [ 3153 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:55.099432 [ 3161 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:55.128114 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:55.340510 [ 7652 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:55.400711 [ 7652 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:55.431072 [ 3154 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:55.485999 [ 3144 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:55.486719 [ 3144 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:55.602663 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:55.677710 [ 3134 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:55.764279 [ 3146 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:55.923579 [ 7652 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:55.969965 [ 7652 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:56.100318 [ 3137 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:56.141729 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:56.432354 [ 3116 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:56.461591 [ 7652 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:56.487579 [ 3119 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:56.487646 [ 3164 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:56.509065 [ 7652 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:56.642355 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:56.678678 [ 3131 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:56.765152 [ 3125 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:57.101604 [ 3109 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:57.189894 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:57.433493 [ 3106 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:57.488953 [ 3107 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:57.488984 [ 3159 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:57.678457 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:57.679813 [ 3110 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:57.766590 [ 3122 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:58.102836 [ 3090 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:58.230012 [ 4675 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:58.356314 [ 7652 ] {d937b95a-fa9a-450b-87f2-4e36cbfddc4f} 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.10542.altinitytest (altinity build)) (from [::1]:37024) (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000335017e7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003345512b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:43:58.359576 [ 7652 ] {d937b95a-fa9a-450b-87f2-4e36cbfddc4f} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000335017e7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003345512b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:43:58.434569 [ 3089 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:58.489926 [ 3076 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:58.490268 [ 3083 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:58.681009 [ 3092 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:58.729815 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:58.768139 [ 3082 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:58.849057 [ 4675 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:58.898429 [ 7652 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:59.103663 [ 3072 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:59.250869 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:59.435654 [ 3077 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:59.470865 [ 7652 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:59.490797 [ 3073 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:59.492015 [ 3058 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:59.520020 [ 7652 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:59.682144 [ 3104 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:59.808866 [ 4675 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:43:59.817673 [ 3068 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:00.020624 [ 4675 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:00.072784 [ 4675 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:00.104955 [ 3067 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:00.301098 [ 4675 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:00.436816 [ 3060 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:00.492073 [ 3396 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:00.493219 [ 3433 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:00.683112 [ 3435 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:00.818747 [ 3406 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:00.838478 [ 4675 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:01.105928 [ 3213 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:01.365244 [ 4675 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:01.438101 [ 3135 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:01.493092 [ 3174 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:01.494494 [ 3061 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:01.684127 [ 3564 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:01.752164 [ 3894 ] {1d058fb3-29ca-436a-b944-f02b7f0265e0} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:35396) (comment: 03203_hive_style_partitioning.sh) (in query: SELECT __table1.column1 AS column1, __table1.column0 AS column0 FROM s3Cluster(test_cluster_one_shard_three_replicas_localhost, 'http://localhost:11111/test/hive_partitioning/column0=Elizabeth/sample.parquet', 'Parquet', '`column1` Nullable(String)') AS __table1 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x0000000030a578da 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030a57120 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000030a33a2d 9. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: DB::StorageObjectStorageSource::createFileIterator(std::shared_ptr, DB::StorageObjectStorage::QuerySettings const&, std::shared_ptr, bool, std::shared_ptr const&, DB::ActionsDAG::Node const*, DB::NamesAndTypesList const&, std::vector, std::allocator>>*, std::function) @ 0x0000000030a1cfe4 10. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:233: DB::(anonymous namespace)::ReadFromObjectStorageStep::createIterator(DB::ActionsDAG::Node const*) @ 0x00000000309f9fcc 11. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:172: DB::(anonymous namespace)::ReadFromObjectStorageStep::applyFilters(DB::ActionDAGNodes) @ 0x00000000309f96a6 12. ./src/Processors/QueryPlan/SourceStepWithFilter.h:0: DB::SourceStepWithFilter::applyFilters() @ 0x000000003c1827e4 13. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizePrimaryKeyConditionAndLimit.cpp:50: DB::QueryPlanOptimizations::optimizePrimaryKeyConditionAndLimit(std::vector> const&) @ 0x000000003c1822fe 14. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:0: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c129752 15. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003beb957a 16. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:0: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003beb64cc 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034cf5e6d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034cf5881 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 2025.10.23 23:44:01.755047 [ 3894 ] {1d058fb3-29ca-436a-b944-f02b7f0265e0} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x0000000030a578da 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030a57120 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000030a33a2d 9. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: DB::StorageObjectStorageSource::createFileIterator(std::shared_ptr, DB::StorageObjectStorage::QuerySettings const&, std::shared_ptr, bool, std::shared_ptr const&, DB::ActionsDAG::Node const*, DB::NamesAndTypesList const&, std::vector, std::allocator>>*, std::function) @ 0x0000000030a1cfe4 10. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:233: DB::(anonymous namespace)::ReadFromObjectStorageStep::createIterator(DB::ActionsDAG::Node const*) @ 0x00000000309f9fcc 11. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:172: DB::(anonymous namespace)::ReadFromObjectStorageStep::applyFilters(DB::ActionDAGNodes) @ 0x00000000309f96a6 12. ./src/Processors/QueryPlan/SourceStepWithFilter.h:0: DB::SourceStepWithFilter::applyFilters() @ 0x000000003c1827e4 13. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizePrimaryKeyConditionAndLimit.cpp:50: DB::QueryPlanOptimizations::optimizePrimaryKeyConditionAndLimit(std::vector> const&) @ 0x000000003c1822fe 14. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:0: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c129752 15. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003beb957a 16. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:0: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003beb64cc 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034cf5e6d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034cf5881 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 2025.10.23 23:44:01.820047 [ 3538 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:01.936557 [ 4675 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:02.106728 [ 3561 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:02.201921 [ 4675 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:02.251940 [ 4675 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:02.410066 [ 4675 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:02.438984 [ 3556 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:02.494079 [ 3559 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:02.495546 [ 3550 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:02.582007 [ 7652 ] {c52064c9-dc70-4db7-87b4-841b31b76ff9} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x0000000030a578da 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030a57120 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000030a33a2d 9. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: DB::StorageObjectStorageSource::createFileIterator(std::shared_ptr, DB::StorageObjectStorage::QuerySettings const&, std::shared_ptr, bool, std::shared_ptr const&, DB::ActionsDAG::Node const*, DB::NamesAndTypesList const&, std::vector, std::allocator>>*, std::function) @ 0x0000000030a1cfe4 10. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:233: DB::(anonymous namespace)::ReadFromObjectStorageStep::createIterator(DB::ActionsDAG::Node const*) @ 0x00000000309f9fcc 11. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:172: DB::(anonymous namespace)::ReadFromObjectStorageStep::applyFilters(DB::ActionDAGNodes) @ 0x00000000309f96a6 12. ./src/Processors/QueryPlan/SourceStepWithFilter.h:0: DB::SourceStepWithFilter::applyFilters() @ 0x000000003c1827e4 13. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizePrimaryKeyConditionAndLimit.cpp:50: DB::QueryPlanOptimizations::optimizePrimaryKeyConditionAndLimit(std::vector> const&) @ 0x000000003c1822fe 14. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:0: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c129752 15. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003beb957a 16. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:0: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003beb64cc 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034cf5e6d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034cf5881 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 . (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37096) (comment: 03203_hive_style_partitioning.sh) (in query: SELECT *, column0 FROM s3Cluster(test_cluster_one_shard_three_replicas_localhost, '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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002019af32 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000003a7e3e0c 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::Connection::receivePacket() @ 0x000000003a7ff61b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:340: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003a8df9b9 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003a8df1b3 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:0: DB::RemoteQueryExecutor::finish() @ 0x00000000322ecf38 8. ./build_docker/./src/Processors/Sources/RemoteSource.cpp:231: DB::RemoteSource::onUpdatePorts() @ 0x000000003bb2376e 9. ./contrib/llvm-project/libcxx/include/__mutex_base:143: DB::ExecutingGraph::updateNode(unsigned long, std::queue>>&, std::queue>>&) @ 0x000000003aeb550c 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:292: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6309 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 13. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:44:02.585932 [ 10275 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:39750, 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x00000000204bfd30 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x00000000204c0cc1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a8112cd 6. DB::ReadBuffer::next() @ 0x00000000095b468f 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000003abd729e 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:02.588102 [ 7652 ] {c52064c9-dc70-4db7-87b4-841b31b76ff9} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x0000000030a578da 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030a57120 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000030a33a2d 9. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: DB::StorageObjectStorageSource::createFileIterator(std::shared_ptr, DB::StorageObjectStorage::QuerySettings const&, std::shared_ptr, bool, std::shared_ptr const&, DB::ActionsDAG::Node const*, DB::NamesAndTypesList const&, std::vector, std::allocator>>*, std::function) @ 0x0000000030a1cfe4 10. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:233: DB::(anonymous namespace)::ReadFromObjectStorageStep::createIterator(DB::ActionsDAG::Node const*) @ 0x00000000309f9fcc 11. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:172: DB::(anonymous namespace)::ReadFromObjectStorageStep::applyFilters(DB::ActionDAGNodes) @ 0x00000000309f96a6 12. ./src/Processors/QueryPlan/SourceStepWithFilter.h:0: DB::SourceStepWithFilter::applyFilters() @ 0x000000003c1827e4 13. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizePrimaryKeyConditionAndLimit.cpp:50: DB::QueryPlanOptimizations::optimizePrimaryKeyConditionAndLimit(std::vector> const&) @ 0x000000003c1822fe 14. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:0: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c129752 15. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003beb957a 16. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:0: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003beb64cc 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034cf5e6d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034cf5881 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 . (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002019af32 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000003a7e3e0c 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::Connection::receivePacket() @ 0x000000003a7ff61b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:340: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003a8df9b9 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003a8df1b3 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:0: DB::RemoteQueryExecutor::finish() @ 0x00000000322ecf38 8. ./build_docker/./src/Processors/Sources/RemoteSource.cpp:231: DB::RemoteSource::onUpdatePorts() @ 0x000000003bb2376e 9. ./contrib/llvm-project/libcxx/include/__mutex_base:143: DB::ExecutingGraph::updateNode(unsigned long, std::queue>>&, std::queue>>&) @ 0x000000003aeb550c 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:292: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6309 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 13. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:44:02.684986 [ 3555 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:02.751290 [ 7652 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:02.813272 [ 7652 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:02.821089 [ 3527 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:03.011538 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:03.107631 [ 3541 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:03.210957 [ 4675 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:03.256233 [ 4675 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:03.440056 [ 3531 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:03.452646 [ 4675 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:03.495066 [ 3548 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:03.496580 [ 3528 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:03.685866 [ 3546 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:03.772426 [ 4675 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:03.814899 [ 4675 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:03.822216 [ 3547 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:04.044573 [ 4675 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:04.108613 [ 3518 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:04.441052 [ 3511 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:04.492665 [ 4675 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:04.496063 [ 3524 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:04.498005 [ 3508 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:04.686697 [ 3510 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:04.823148 [ 3501 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:04.903770 [ 7652 ] {acc045ec-2b34-405d-a3f2-4b21a364fb49} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37196) (comment: 02025_dictionary_view_different_db.sql) (in query: DROP DICTIONARY 2025_test_db.test_dictionary;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349417ab 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:44:04.905988 [ 7652 ] {acc045ec-2b34-405d-a3f2-4b21a364fb49} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349417ab 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:44:05.109510 [ 3495 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:05.246746 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:05.441842 [ 3494 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:05.497003 [ 3491 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:05.498861 [ 3485 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:05.685175 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:05.687525 [ 3487 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:05.824242 [ 3481 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:06.110486 [ 3512 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:06.396297 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:06.442836 [ 3490 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:06.497870 [ 3489 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:06.499520 [ 3473 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:06.688699 [ 3472 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:06.761984 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:06.789586 [ 4675 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:06.825314 [ 3466 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:06.839421 [ 7652 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:07.111340 [ 3461 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:07.360354 [ 7652 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:07.411243 [ 4675 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:07.444435 [ 3455 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:07.446196 [ 7652 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:07.499088 [ 3450 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:07.500757 [ 3464 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:07.526583 [ 4675 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:07.689813 [ 3456 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:07.804295 [ 4675 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:07.826366 [ 3442 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:08.112252 [ 3419 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:08.115493 [ 4675 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:08.164057 [ 4675 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:08.197660 [ 4675 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:08.445543 [ 3415 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:08.500306 [ 3412 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:08.501833 [ 3417 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:08.521485 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:08.690830 [ 3386 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:08.718542 [ 9557 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:08.763316 [ 9557 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:08.776202 [ 9557 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:08.827309 [ 3383 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:08.841158 [ 4675 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:09.113575 [ 3367 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:09.281897 [ 9557 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:09.329904 [ 9557 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:09.446401 [ 3376 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:09.501435 [ 3364 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:09.502838 [ 3360 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:09.677940 [ 4675 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:09.691655 [ 3358 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:09.830066 [ 3363 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:09.866906 [ 4675 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:09.898058 [ 4745 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:09.950455 [ 4675 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:10.114871 [ 3353 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:10.447254 [ 3336 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:10.468507 [ 9557 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:10.502334 [ 3365 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:10.503624 [ 3326 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:10.518332 [ 9557 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:10.692648 [ 3338 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:10.818494 [ 4675 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:10.831135 [ 3328 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:10.922770 [ 4675 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:11.083947 [ 4675 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:11.152787 [ 3348 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:11.257376 [ 4675 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:11.448582 [ 3320 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:11.503187 [ 3321 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:11.504388 [ 3313 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:11.693405 [ 3298 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:11.832301 [ 3299 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:11.897548 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:11.963337 [ 4745 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:12.153953 [ 3312 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:12.449597 [ 3287 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:12.504727 [ 3278 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:12.505372 [ 3283 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:12.694185 [ 3275 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:12.833253 [ 3276 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:13.031835 [ 4745 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:13.034931 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:13.154872 [ 3263 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:13.450694 [ 3250 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:13.505862 [ 3246 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:13.506583 [ 3254 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:13.614433 [ 9557 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:13.659133 [ 4745 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:13.695379 [ 3256 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:13.834275 [ 3242 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:14.003512 [ 9453 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x00000000315a10ad 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159da2f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b6b4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa269fb 10. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:14.085771 [ 4745 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:14.101793 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:14.155624 [ 3231 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:14.428310 [ 9453 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x00000000315a10ad 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159da2f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b6b4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa269fb 10. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:14.451598 [ 3228 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:14.506992 [ 3229 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:14.507627 [ 3227 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:14.696456 [ 3218 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:14.758469 [ 4745 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:14.804199 [ 4745 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:14.835205 [ 3225 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:15.126665 [ 4745 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:15.156851 [ 3216 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:15.191020 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:15.305814 [ 4745 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:15.351612 [ 4745 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:15.452657 [ 3219 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:15.508602 [ 3196 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:15.563631 [ 3199 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:15.697488 [ 3194 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:15.836523 [ 3191 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:15.868692 [ 9557 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:15.916408 [ 9557 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:16.157926 [ 3186 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:16.176068 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:16.218725 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:16.429668 [ 9557 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:16.453446 [ 3165 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:16.485038 [ 9557 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:16.509446 [ 3153 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:16.564811 [ 3160 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:16.698419 [ 3161 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:16.837898 [ 3151 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:16.998217 [ 9557 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:17.042559 [ 9557 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:17.158922 [ 3150 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:17.247351 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:17.356391 [ 4745 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:17.454207 [ 3146 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:17.510291 [ 3137 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:17.565761 [ 3136 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:17.699264 [ 3121 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:17.839064 [ 3140 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:18.160064 [ 3113 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:18.240910 [ 9557 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:18.299257 [ 4745 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:18.308226 [ 9557 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:18.432251 [ 4745 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:18.454903 [ 3108 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:18.511119 [ 3106 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:18.567202 [ 3159 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:18.700212 [ 3103 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:18.811216 [ 2904 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:18.840274 [ 3093 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:18.856255 [ 2904 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:19.160869 [ 3100 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:19.330088 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:19.391687 [ 3933 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:19.443045 [ 2904 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:19.455607 [ 3089 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:19.490586 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:19.564136 [ 3071 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:19.568466 [ 3086 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:19.701098 [ 3085 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:19.841283 [ 3080 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:19.948859 [ 4745 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:19.995212 [ 4745 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:20.161807 [ 3077 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:20.456607 [ 3059 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:20.491235 [ 3933 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:20.495243 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:20.540124 [ 3933 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:20.564975 [ 3062 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:20.569653 [ 3104 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:20.625181 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:20.702111 [ 3056 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:20.842512 [ 3067 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:21.162930 [ 3054 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:21.457427 [ 3433 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:21.565809 [ 3391 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:21.570628 [ 3435 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:21.625280 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:21.646560 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:21.702950 [ 3236 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:21.740500 [ 2904 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:21.787597 [ 2904 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:21.844161 [ 3291 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:22.164416 [ 3168 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:22.298898 [ 2904 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:22.351410 [ 2904 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:22.458674 [ 3174 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:22.566942 [ 3563 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:22.571420 [ 3098 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:22.658671 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:22.681981 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:22.703641 [ 3557 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:22.845192 [ 3544 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:22.925429 [ 2904 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:22.934433 [ 3933 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:23.165735 [ 3534 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:23.450133 [ 2904 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:23.459659 [ 3074 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:23.568366 [ 3541 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:23.572433 [ 3529 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:23.689234 [ 2904 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:23.705286 [ 3548 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:23.725057 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:23.729264 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:23.755058 [ 9453 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x00000000315a10ad 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159da2f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b6b4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa269fb 10. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:23.846405 [ 3546 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:24.166735 [ 3521 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:24.244539 [ 2904 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:24.310145 [ 2904 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:24.460824 [ 3509 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:24.569383 [ 3513 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:24.573318 [ 3522 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:24.706242 [ 3501 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:24.797991 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:24.848097 [ 3496 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:24.882518 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:25.256641 [ 3484 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:25.461725 [ 3479 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:25.484387 [ 2904 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:25.530740 [ 2904 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:25.570465 [ 3512 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:25.574231 [ 3475 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:25.707253 [ 3480 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:25.846788 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:25.849676 [ 3467 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:25.948806 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:26.044622 [ 2904 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:26.093734 [ 2904 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:26.257671 [ 3461 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:26.462755 [ 3470 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:26.572282 [ 3452 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:26.575321 [ 3450 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:26.622328 [ 2904 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:26.665000 [ 2904 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:26.708351 [ 3439 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:26.850795 [ 3442 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:26.919255 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:27.004048 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:27.258693 [ 3429 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:27.262231 [ 2904 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:27.306854 [ 2904 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:27.464396 [ 3474 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:27.573343 [ 3432 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:27.576404 [ 3425 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:27.709892 [ 3428 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:27.825189 [ 2904 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:27.851883 [ 3416 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:27.870853 [ 2904 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:28.004404 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:28.049904 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:28.259474 [ 3410 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:28.465221 [ 3411 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:28.574765 [ 3402 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:28.577393 [ 3393 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:28.710720 [ 3408 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:28.853271 [ 3404 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:29.035579 [ 3933 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:29.060205 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:29.104687 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:29.118837 [ 2903 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:29.260684 [ 3394 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:29.466349 [ 3383 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:29.576554 [ 3369 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:29.578453 [ 3375 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:29.592933 [ 2904 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:29.640632 [ 2904 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:29.711648 [ 3370 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:29.854367 [ 3379 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:30.115009 [ 3933 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:30.150514 [ 2904 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:30.158013 [ 2903 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:30.191483 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:30.261699 [ 3362 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:30.467393 [ 3359 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:30.510463 [ 4745 ] {86021da4-7be6-40c7-98bd-ced127ca57ec} executeQuery: Code: 241. DB::Exception: Memory tracker (for query): fault injected. Would use 9.54 MiB (attempt to allocate chunk of 1535472 bytes), maximum: 9.31 GiB: While executing NumbersRange. (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:54694) (comment: 00804_test_delta_codec_compression.sql) (in query: INSERT INTO default_codec_synthetic SELECT number 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, String&&, long&, String&&) @ 0x000000002009baa7 4. ./build_docker/./src/Common/MemoryTracker.cpp:284: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002009a3d3 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099272 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7ca1d 7. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ff775a4 8. ./src/Common/PODArray.h:120: DB::ColumnVector::ColumnVector(unsigned long) @ 0x0000000037909caa 9. ./src/Common/COW.h:0: DB::(anonymous namespace)::NumbersRangedSource::generate() @ 0x000000003c0c5fc6 10. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae71153 11. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 12. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 16. ./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*) @ 0x000000003aea17d9 17. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:44:30.519245 [ 4745 ] {86021da4-7be6-40c7-98bd-ced127ca57ec} TCPHandler: Code: 241. DB::Exception: Memory tracker (for query): fault injected. Would use 9.54 MiB (attempt to allocate chunk of 1535472 bytes), maximum: 9.31 GiB: While executing NumbersRange. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, String&&, long&, String&&) @ 0x000000002009baa7 4. ./build_docker/./src/Common/MemoryTracker.cpp:284: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002009a3d3 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099272 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7ca1d 7. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ff775a4 8. ./src/Common/PODArray.h:120: DB::ColumnVector::ColumnVector(unsigned long) @ 0x0000000037909caa 9. ./src/Common/COW.h:0: DB::(anonymous namespace)::NumbersRangedSource::generate() @ 0x000000003c0c5fc6 10. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae71153 11. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 12. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 16. ./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*) @ 0x000000003aea17d9 17. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:44:30.577707 [ 3354 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:30.579224 [ 3373 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:30.624527 [ 2904 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:30.712711 [ 3343 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:30.745394 [ 2904 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:30.855366 [ 3339 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:31.194233 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:31.262440 [ 3355 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:31.278533 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:31.365961 [ 2903 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:31.451931 [ 3933 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:31.468549 [ 3342 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:31.578911 [ 3314 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:31.580192 [ 3320 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:31.713685 [ 3303 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:31.856805 [ 3285 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:32.263230 [ 3251 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:32.276198 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:32.335005 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:32.469402 [ 3239 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:32.580001 [ 3241 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:32.581276 [ 3234 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:32.714494 [ 3220 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:32.858096 [ 3214 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:32.884607 [ 3933 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:32.973920 [ 3933 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:33.264094 [ 3188 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:33.378430 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:33.400924 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:33.470235 [ 3180 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:33.510224 [ 3933 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:33.555935 [ 3933 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:33.580809 [ 3178 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:33.582163 [ 3167 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:33.715256 [ 3126 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:33.859051 [ 3118 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:34.066702 [ 3933 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:34.118453 [ 3933 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:34.264854 [ 3120 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:34.427324 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:34.466905 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:34.471107 [ 3108 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:34.581806 [ 3159 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:34.583321 [ 3117 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:34.646263 [ 3933 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:34.692957 [ 3933 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:34.716244 [ 3110 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:34.860541 [ 3093 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:35.189798 [ 2903 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:35.235197 [ 2903 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:35.265755 [ 3091 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:35.472061 [ 3096 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:35.565645 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:35.582958 [ 3086 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:35.671100 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:35.677249 [ 3082 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:35.717063 [ 3075 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:35.861727 [ 3078 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:36.266655 [ 3079 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:36.473167 [ 3064 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:36.606006 [ 3068 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:36.635532 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:36.678295 [ 3055 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:36.718067 [ 3444 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:36.732060 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:36.862891 [ 3060 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:37.014572 [ 3648 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {60ee07fc-67dc-4a3f-94ea-a31cb10c5a92::202510_1_131_26}: 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 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) @ 0x0000000039c89948 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000003999bfb7 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 @ 0x00000000399942f0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000039d15c04 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&) @ 0x0000000039d20399 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) @ 0x0000000039d1c606 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000396308a4 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x00000000396235dd 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000003963b3e0 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x00000000396504a0 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3c455d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:37.268004 [ 3329 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:37.474161 [ 3236 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:37.606918 [ 3063 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:37.679951 [ 3135 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:37.719012 [ 3124 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:37.754592 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:37.768181 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:37.905991 [ 3564 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:38.269542 [ 3560 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:38.475310 [ 3536 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:38.607933 [ 3074 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:38.732502 [ 3541 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:38.732656 [ 3558 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:38.889212 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:38.890898 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:38.907024 [ 3528 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:39.270677 [ 3521 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:39.476477 [ 3524 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:39.608695 [ 3510 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:39.733649 [ 3500 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:39.733705 [ 3504 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:39.908109 [ 3495 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:40.029560 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:40.092258 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:40.271877 [ 3482 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:40.337585 [ 3933 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:40.385434 [ 3933 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:40.477645 [ 3483 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:40.609521 [ 3490 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:40.734482 [ 3489 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:40.734595 [ 3477 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:40.893010 [ 2903 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:40.909092 [ 3480 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:40.940296 [ 2903 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:41.093665 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:41.168681 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:41.272728 [ 3462 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:41.478973 [ 3460 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:41.610720 [ 3452 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:41.735402 [ 3448 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:41.735582 [ 3454 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:41.910246 [ 3456 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:42.163432 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:42.223555 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:42.273762 [ 3451 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:42.480527 [ 3429 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:42.612453 [ 3474 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:42.736473 [ 3425 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:42.737026 [ 3426 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:42.911122 [ 3419 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:43.272435 [ 4841 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:43.274973 [ 3412 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:43.287433 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:43.362109 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:43.408535 [ 4841 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:43.481746 [ 3421 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:43.613579 [ 3405 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:43.737382 [ 3403 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:43.737781 [ 3397 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:43.907567 [ 3933 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:43.912388 [ 3408 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:43.959927 [ 3933 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:44.301767 [ 3386 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:44.390890 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:44.458741 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:44.482865 [ 3389 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:44.511196 [ 3933 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:44.563577 [ 3933 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:44.614814 [ 3388 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:44.738299 [ 3380 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:44.738673 [ 3378 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:44.913536 [ 3368 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:45.201726 [ 2903 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:45.272024 [ 2903 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:45.302754 [ 3364 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:45.415204 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:45.483797 [ 3362 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:45.530365 [ 3933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:45.616225 [ 3359 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:45.739223 [ 3349 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:45.739429 [ 3340 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:45.870598 [ 2903 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:45.914537 [ 3346 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:45.916244 [ 2903 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:46.303625 [ 3326 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:46.436235 [ 4841 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:46.476494 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:46.484613 [ 3328 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:46.489057 [ 4841 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:46.577957 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:46.617236 [ 3327 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:46.740267 [ 3341 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:46.740385 [ 3348 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:46.915924 [ 3318 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:46.979860 [ 2903 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:47.023265 [ 2903 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:47.304880 [ 3309 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:47.485323 [ 3301 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:47.516703 [ 4841 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:47.546301 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:47.564252 [ 4841 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:47.618193 [ 3308 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:47.627990 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:47.741303 [ 3300 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:47.741309 [ 3302 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:47.917055 [ 3312 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:48.116735 [ 2903 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:48.164861 [ 2903 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:48.264225 [ 3933 ] {90cda711-6bcf-4875-b289-a770f956009e} executeQuery: Code: 497. DB::Exception: user03631_test_1_13783: Not enough privileges. To execute this query, it's necessary to have the grant SELECT ON test_1.test_table. (ACCESS_DENIED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:60866) (comment: 03680_loop_table_function_access_check.sh) (in query: SELECT * FROM loop('test_1', 'test_table') LIMIT 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000312e10fb 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 @ 0x00000000312e0ab3 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x00000000312df5d7 6. ./build_docker/./src/Access/ContextAccess.cpp:825: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x0000000031296331 7. ./src/Access/ContextAccess.h:0: void DB::Context::checkAccessImpl>, std::basic_string_view>>(DB::AccessFlags const&, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x00000000337c440f 8. ./build_docker/./src/Interpreters/Context.cpp:1544: DB::Context::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x00000000337352cf 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::(anonymous namespace)::TableFunctionLoop::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002fdfb8bb 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f70b3 11. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000003374cff2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4838: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003345fff3 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334edd21 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436960 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 2025.10.23 23:44:48.266078 [ 3933 ] {90cda711-6bcf-4875-b289-a770f956009e} TCPHandler: Code: 497. DB::Exception: user03631_test_1_13783: Not enough privileges. To execute this query, it's necessary to have the grant SELECT ON test_1.test_table. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000312e10fb 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 @ 0x00000000312e0ab3 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x00000000312df5d7 6. ./build_docker/./src/Access/ContextAccess.cpp:825: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x0000000031296331 7. ./src/Access/ContextAccess.h:0: void DB::Context::checkAccessImpl>, std::basic_string_view>>(DB::AccessFlags const&, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x00000000337c440f 8. ./build_docker/./src/Interpreters/Context.cpp:1544: DB::Context::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x00000000337352cf 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::(anonymous namespace)::TableFunctionLoop::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002fdfb8bb 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f70b3 11. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000003374cff2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4838: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003345fff3 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334edd21 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436960 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 2025.10.23 23:44:48.305810 [ 3285 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:48.486124 [ 3279 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:48.593775 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:48.619011 [ 3275 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:48.685473 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:48.689299 [ 4841 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:48.735349 [ 2903 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:48.742068 [ 3276 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:48.742168 [ 3268 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:48.917880 [ 3257 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:49.249716 [ 2903 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:49.297141 [ 2903 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:49.306932 [ 3251 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:49.486993 [ 3246 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:49.619910 [ 3254 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:49.665692 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:49.728244 [ 3894 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:49.742817 [ 3240 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:49.743224 [ 3258 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:49.898933 [ 2903 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:49.918756 [ 3247 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:49.944084 [ 4841 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:50.008519 [ 4841 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:50.308288 [ 3226 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:50.488432 [ 3232 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:50.547797 [ 2903 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:50.594556 [ 2903 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:50.620759 [ 3222 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:50.687157 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:50.743620 [ 3210 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:50.744524 [ 3216 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:50.785808 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:50.919626 [ 3209 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:51.131235 [ 4841 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:51.178624 [ 4841 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:51.189806 [ 4841 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:51.309264 [ 3196 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:51.489453 [ 3202 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:51.621744 [ 3191 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:51.702931 [ 4841 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:51.719306 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:51.744464 [ 3192 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:51.745941 [ 3186 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:51.752251 [ 2903 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:51.806778 [ 2903 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:51.889309 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:51.990782 [ 3180 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:52.310180 [ 3171 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:52.360215 [ 4841 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:52.408756 [ 4841 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_3 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:525: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000339a7a4b 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x0000000033756a2f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000003abd68f3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:52.490473 [ 3178 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:52.623112 [ 3166 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:52.745505 [ 3158 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:52.747127 [ 3161 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:52.906943 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:52.992238 [ 3151 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:53.026665 [ 3894 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:53.311312 [ 3138 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:53.491997 [ 3157 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:53.624698 [ 3136 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:53.813689 [ 3140 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:53.813865 [ 3118 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:53.971061 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:53.993148 [ 3162 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:54.055477 [ 9453 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x00000000315a10ad 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159da2f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b6b4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa269fb 10. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:54.147494 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:54.312221 [ 3120 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:54.481180 [ 9453 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x00000000315a10ad 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159da2f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b6b4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa269fb 10. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:54.492836 [ 3127 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:54.625717 [ 3101 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:54.722544 [ 20770 ] {} test_1.pk_func (805126a8-e242-49b5-8c96-38d5384dcd20): dropAllData: got exception removing parts from disk, removing successfully removed parts from memory. 2025.10.23 23:44:54.724241 [ 20770 ] {} DatabaseCatalog: Cannot drop table test_1.pk_func (805126a8-e242-49b5-8c96-38d5384dcd20). Will retry later.: 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::clearPartsFromFilesystemImpl(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>*) @ 0x0000000039746581 8. ./contrib/llvm-project/libcxx/include/__hash_table:935: DB::MergeTreeData::clearPartsFromFilesystem(std::vector, std::allocator>> const&, bool, std::unordered_set, std::equal_to, std::allocator>*) @ 0x000000003973f352 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3004: DB::MergeTreeData::dropAllData() @ 0x0000000039755a8a 10. ./build_docker/./src/Storages/StorageMergeTree.cpp:317: DB::StorageMergeTree::drop() @ 0x000000003a2f1c13 11. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x00000000339c9eb0 12. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: void std::__function::__policy_invoker::__call_impl, std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000339ec8c3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000303f120c 14. ./contrib/llvm-project/libcxx/include/future:1694: std::__packaged_task_func>, std::function>::operator()(std::function&&, Priority)::'lambda'(), std::allocator>, std::function>::operator()(std::function&&, Priority)::'lambda'()>, void ()>::operator()() @ 0x00000000303f0fed 15. ./contrib/llvm-project/libcxx/include/future:2069: std::packaged_task::operator()() @ 0x00000000214b57dd 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000303f36ee 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 22. ? @ 0x00007f100c857ac3 23. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:54.814933 [ 3093 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:54.814965 [ 3097 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:54.994124 [ 3089 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:55.013479 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:55.189870 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:55.313187 [ 3096 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:55.494091 [ 3071 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:55.626870 [ 3084 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:55.816273 [ 3078 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:55.816468 [ 3095 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:55.995138 [ 3105 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:56.080864 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:56.264272 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:56.314348 [ 3068 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:56.495432 [ 3056 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:56.628258 [ 3067 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:56.817353 [ 3060 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:56.817536 [ 3443 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:57.068201 [ 3319 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:57.169563 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:57.315365 [ 3236 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:57.357859 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:57.496987 [ 3291 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:57.629635 [ 3063 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:57.818418 [ 3141 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:57.818488 [ 3168 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:58.069230 [ 3207 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:58.262316 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:58.316658 [ 3201 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:58.392929 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:58.498273 [ 3544 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:58.631153 [ 3111 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:58.819559 [ 3540 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:58.819765 [ 3559 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:59.070333 [ 3555 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:59.314187 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:59.317619 [ 3543 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:59.438059 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:44:59.499143 [ 3531 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:59.632791 [ 3554 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:59.821052 [ 3546 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:59.821102 [ 3523 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:00.072071 [ 3537 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:00.318503 [ 3518 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:00.372753 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:00.500218 [ 3520 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:00.511578 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:00.634004 [ 3524 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:00.885379 [ 3513 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:00.885507 [ 3522 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:01.073911 [ 3503 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:01.319561 [ 3499 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:01.411590 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:01.501379 [ 3496 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:01.573963 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:01.634976 [ 3502 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:01.886352 [ 3492 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:01.886735 [ 3482 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:02.075160 [ 3486 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:02.320699 [ 3490 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:02.479529 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:02.502384 [ 3472 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:02.635881 [ 3468 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:02.801271 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:02.887315 [ 3471 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:02.888361 [ 3457 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:03.076385 [ 3459 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:03.321736 [ 3449 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:03.503162 [ 3446 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:03.553444 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:03.631259 [ 3651 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b37203c3-8fb0-4cdf-8555-9946d278f55b::202510_86_111_5}: 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 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) @ 0x0000000039c89948 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000003999bfb7 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 @ 0x00000000399942f0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000039d15c04 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&) @ 0x0000000039d20399 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) @ 0x0000000039d1c606 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000396308a4 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x00000000396235dd 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000003963b3e0 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x00000000396504a0 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3c455d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:03.636865 [ 3442 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:03.853097 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:03.888219 [ 3533 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:03.889668 [ 3437 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:04.077455 [ 3474 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:04.157999 [ 3656 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b37203c3-8fb0-4cdf-8555-9946d278f55b::202510_86_111_5}: 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 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) @ 0x0000000039c89948 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000003999bfb7 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 @ 0x00000000399942f0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000039d15c04 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&) @ 0x0000000039d20399 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) @ 0x0000000039d1c606 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000396308a4 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x00000000396235dd 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000003963b3e0 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x00000000396504a0 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3c455d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:04.322746 [ 3430 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:04.350424 [ 2903 ] {b40e6817-f2aa-49e3-9ea4-9e9751606cbf} executeQuery: Code: 241. DB::Exception: Memory tracker (for query): fault injected. Would use 31.23 MiB (attempt to allocate chunk of 1429808 bytes), maximum: 9.31 GiB: while converting source column number to destination column B: while executing 'FUNCTION _CAST(number :: 1, Int64 :: 4) -> _CAST(number, Int64) Int64 : 3'. (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:33040) (comment: 01137_order_by_func.sql) (in query: INSERT INTO nORX SELECT 111, number, number FROM numbers(10000000);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, String&&, long&, String&&) @ 0x000000002009baa7 4. ./build_docker/./src/Common/MemoryTracker.cpp:284: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002009a3d3 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099272 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7ca1d 7. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ff775a4 8. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x000000000838765c 9. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000008a9d60d 10. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008a91b5f 11. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d57db 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffeaa 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d403f 16. 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) @ 0x000000000876e509 17. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086d2b34 18. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffeaa 19. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601e5f 20. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 21. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a24ade 22. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b82c484 23. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acdc84 24. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae66ecb 25. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 29. ./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*) @ 0x000000003aea17d9 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 2025.10.23 23:45:04.361460 [ 2903 ] {b40e6817-f2aa-49e3-9ea4-9e9751606cbf} TCPHandler: Code: 241. DB::Exception: Memory tracker (for query): fault injected. Would use 31.23 MiB (attempt to allocate chunk of 1429808 bytes), maximum: 9.31 GiB: while converting source column number to destination column B: while executing 'FUNCTION _CAST(number :: 1, Int64 :: 4) -> _CAST(number, Int64) Int64 : 3'. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, String&&, long&, String&&) @ 0x000000002009baa7 4. ./build_docker/./src/Common/MemoryTracker.cpp:284: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002009a3d3 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099272 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7ca1d 7. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ff775a4 8. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x000000000838765c 9. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000008a9d60d 10. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008a91b5f 11. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d57db 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffeaa 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083d403f 16. 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) @ 0x000000000876e509 17. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086d2b34 18. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffeaa 19. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601e5f 20. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 21. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a24ade 22. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b82c484 23. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acdc84 24. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae66ecb 25. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 29. ./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*) @ 0x000000003aea17d9 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 2025.10.23 23:45:04.504181 [ 3416 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:04.573890 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:04.637994 [ 3420 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:04.889041 [ 3412 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:04.890645 [ 3417 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:04.922207 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:05.078430 [ 3407 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:05.323907 [ 3403 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:05.505076 [ 3395 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:05.638916 [ 3384 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:05.666063 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:05.889952 [ 3387 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:05.891469 [ 3386 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:05.968531 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:06.079356 [ 3369 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:06.324736 [ 3382 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:06.505959 [ 3379 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:06.640179 [ 3376 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:06.731157 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:06.890732 [ 3351 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:06.892616 [ 3361 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:07.012004 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:07.080533 [ 3340 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:07.325650 [ 3350 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:07.507342 [ 3365 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:07.641291 [ 3355 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:07.757478 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:07.891664 [ 3330 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:07.893769 [ 3356 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:08.070241 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:08.081748 [ 3331 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:08.326704 [ 3335 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:08.509264 [ 3316 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:08.642286 [ 3309 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:08.811277 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:08.892977 [ 3298 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:08.895042 [ 3297 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:09.082991 [ 3294 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:09.205676 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:09.328061 [ 3312 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:09.510509 [ 3289 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:09.643210 [ 3278 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:09.893992 [ 3272 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:09.896469 [ 3281 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:09.898966 [ 3644 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {26a86919-b755-436d-800b-c04857d425d1::202510_1_122_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 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) @ 0x0000000039c89948 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000003999bfb7 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 @ 0x00000000399942f0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000039d15c04 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&) @ 0x0000000039d20399 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) @ 0x0000000039d1c606 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000396308a4 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x00000000396235dd 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000003963b3e0 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x00000000396504a0 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3c455d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:09.921681 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:10.084297 [ 3270 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:10.290301 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:10.329486 [ 3264 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:10.511985 [ 3260 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:10.644451 [ 3262 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:10.895326 [ 3254 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:10.897507 [ 3256 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:10.982354 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:11.085341 [ 3244 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:11.330482 [ 3241 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:11.354403 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:11.513386 [ 3237 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:11.645742 [ 3230 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:11.896301 [ 3222 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:11.898604 [ 3214 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:12.086329 [ 3225 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:12.225016 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:12.331516 [ 3206 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:12.384175 [ 4841 ] {a81f44f5-5ca7-467c-9a6e-4d62d2bc194c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=749). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44704) (comment: 01518_select_in_null.sql) (in query: select count() from t1 where cast(c1 as Nullable(String)) in (select 'BBBBBB' union all select 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:45:12.387153 [ 4841 ] {a81f44f5-5ca7-467c-9a6e-4d62d2bc194c} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=749). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:45:12.415151 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:12.514521 [ 3219 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:12.647047 [ 3193 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:12.897259 [ 3205 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:12.900117 [ 3191 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:13.087502 [ 3186 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:13.296921 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:13.332670 [ 3187 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:13.471361 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:13.515431 [ 3182 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:13.648212 [ 3171 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:13.898413 [ 3148 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:13.901211 [ 3160 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:14.088834 [ 3152 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:14.331982 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:14.333410 [ 3145 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:14.516238 [ 3144 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:14.520517 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:14.649576 [ 3134 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:14.899489 [ 3177 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:14.902245 [ 3136 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:15.090021 [ 3121 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:15.334193 [ 3118 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:15.388856 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:15.517028 [ 3162 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:15.592867 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:15.650741 [ 3125 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:15.901002 [ 3120 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:15.903227 [ 3113 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:16.091020 [ 3107 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:16.335023 [ 3097 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:16.441810 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:16.517800 [ 3100 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:16.651592 [ 3087 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:16.671652 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:16.902329 [ 3092 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:16.904426 [ 3071 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:17.092234 [ 3075 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:17.335957 [ 3072 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:17.518592 [ 3070 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:17.526004 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:17.653014 [ 3058 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:17.750187 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:17.903300 [ 3065 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:17.905283 [ 3056 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:18.093676 [ 3054 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:18.336669 [ 3396 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:18.519494 [ 3391 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:18.565404 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:18.654172 [ 3236 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:18.802301 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:18.904447 [ 3322 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:18.906043 [ 3213 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:19.095081 [ 3168 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:19.337446 [ 3124 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:19.520398 [ 3562 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:19.616176 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:19.655012 [ 3201 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:19.905251 [ 3556 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:19.906864 [ 3540 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:19.921196 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:20.096313 [ 3534 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:20.338468 [ 3074 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:20.521440 [ 3543 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:20.656006 [ 3541 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:20.658149 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:20.906329 [ 3530 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:20.908073 [ 3525 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:20.986618 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:21.097255 [ 3523 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:21.339404 [ 3515 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:21.522420 [ 3539 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:21.656932 [ 3511 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:21.733750 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:21.907152 [ 3508 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:21.909274 [ 3513 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:22.093207 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:22.098033 [ 3500 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:22.340199 [ 3496 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:22.523385 [ 3498 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:22.657872 [ 3494 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:22.750162 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:22.908560 [ 3482 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:22.910433 [ 3484 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:23.098980 [ 3486 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:23.205520 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:23.341161 [ 3490 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:23.524195 [ 3477 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:23.659052 [ 3466 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:23.799566 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:23.828160 [ 9453 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x00000000315a10ad 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159da2f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b6b4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa269fb 10. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:23.909822 [ 3460 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:23.911384 [ 3461 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:24.100244 [ 3455 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:24.241105 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:24.342215 [ 3454 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:24.524987 [ 3442 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:24.660271 [ 3429 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:24.910814 [ 3423 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:24.912752 [ 3438 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:24.923448 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:25.101235 [ 3426 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:25.293424 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:25.343021 [ 3415 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:25.525922 [ 3417 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:25.661434 [ 3407 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:25.912081 [ 3399 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:25.913966 [ 3401 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:26.051958 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:26.102413 [ 3386 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:26.344322 [ 3389 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:26.366332 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:26.526896 [ 3381 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:26.662396 [ 3380 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:26.913301 [ 3367 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:26.914879 [ 3382 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:27.084412 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:27.103565 [ 3366 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:27.345420 [ 3364 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:27.441000 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:27.528288 [ 3351 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:27.663724 [ 3359 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:27.914391 [ 3354 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:27.915665 [ 3373 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:28.105040 [ 3346 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:28.127900 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:28.346331 [ 3326 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:28.529299 [ 3330 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:28.558345 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:28.664976 [ 3333 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:28.915523 [ 3341 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:28.916840 [ 3335 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:29.106457 [ 3311 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:29.187050 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:29.347127 [ 3310 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:29.530257 [ 3305 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:29.642807 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:29.666118 [ 3313 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:29.916639 [ 3308 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:29.917697 [ 3303 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:30.107553 [ 3312 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:30.216894 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:30.348142 [ 3278 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:30.531259 [ 3283 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:30.667038 [ 3279 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:30.693019 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:30.918001 [ 3273 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:30.918623 [ 3269 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:31.108694 [ 3270 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:31.252283 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:31.349275 [ 3263 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:31.532598 [ 3271 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:31.668378 [ 3251 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:31.726739 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:31.919029 [ 3259 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:31.919581 [ 3249 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:32.109925 [ 3247 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:32.350290 [ 3237 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:32.470490 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:32.533549 [ 3230 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:32.669539 [ 3229 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:32.845297 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:32.920089 [ 3214 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:32.920657 [ 3221 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:33.110971 [ 3215 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:33.175095 [ 3650 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {26a86919-b755-436d-800b-c04857d425d1::202510_1_124_56}: 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 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) @ 0x0000000039c89948 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000003999bfb7 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 @ 0x00000000399942f0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000039d15c04 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&) @ 0x0000000039d20399 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) @ 0x0000000039d1c606 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000396308a4 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x00000000396235dd 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000003963b3e0 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x00000000396504a0 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3c455d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:33.351219 [ 3196 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:33.530828 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:33.534266 [ 3193 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:33.670906 [ 3205 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:33.899612 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:33.921110 [ 3186 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:33.921732 [ 3181 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:34.111885 [ 3180 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:34.352495 [ 3182 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:34.535366 [ 3171 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:34.591779 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:34.672181 [ 3167 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:34.922021 [ 3148 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:34.922658 [ 3148 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:34.965381 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:35.113208 [ 3151 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:35.353763 [ 3150 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:35.536239 [ 3144 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:35.634005 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:35.673320 [ 3157 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:35.922931 [ 3126 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:35.923615 [ 3143 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:36.007045 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:36.114218 [ 3119 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:36.354874 [ 3129 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:36.537205 [ 3125 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:36.672083 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:36.674466 [ 3109 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:36.924355 [ 3113 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:36.924905 [ 3132 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:37.057447 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:37.115199 [ 3110 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:37.356106 [ 3099 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:37.538305 [ 3090 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:37.675644 [ 3088 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:37.726214 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:37.925542 [ 3076 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:37.926099 [ 3096 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:38.118424 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:38.205756 [ 3078 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:38.357344 [ 3105 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:38.539595 [ 3070 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:38.676928 [ 3059 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:38.789420 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:38.926845 [ 3065 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:38.927210 [ 3069 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:39.206941 [ 3443 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:39.213103 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:39.358604 [ 3391 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:39.541318 [ 3418 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:39.678286 [ 3223 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:39.852902 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:39.928496 [ 3063 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:39.928558 [ 3197 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:40.208307 [ 3124 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:40.253119 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:40.359937 [ 3563 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:40.542326 [ 3207 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:40.679564 [ 3564 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:40.914123 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:40.929490 [ 3561 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:40.930160 [ 3560 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:41.209323 [ 3550 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:41.324187 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:41.360823 [ 3555 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:41.543283 [ 3553 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:41.680982 [ 3527 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:41.930417 [ 3543 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:41.931330 [ 3529 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:41.964393 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:42.210486 [ 3548 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:42.362037 [ 3525 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:42.530783 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:42.584895 [ 3523 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:42.682102 [ 3516 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:42.931409 [ 3515 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:42.932276 [ 3518 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:43.048543 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:43.211522 [ 3506 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:43.363205 [ 3505 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:43.586236 [ 3522 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:43.614435 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:43.683117 [ 3501 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:43.933117 [ 3497 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:43.933117 [ 3499 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:44.078463 [ 9453 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x00000000315a10ad 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159da2f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b6b4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa269fb 10. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:44.135386 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:44.212380 [ 3494 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:44.364388 [ 3487 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:44.555531 [ 9453 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x00000000315a10ad 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159da2f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b6b4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa269fb 10. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:44.587320 [ 3483 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:44.693859 [ 3475 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:44.699091 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:44.934110 [ 3489 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:44.934127 [ 3490 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:45.202231 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:45.213417 [ 3480 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:45.365458 [ 3465 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:45.588470 [ 3463 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:45.695067 [ 3460 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:45.781756 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:45.934908 [ 3455 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:45.934975 [ 3452 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:46.214612 [ 3454 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:46.250226 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:46.366881 [ 3450 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:46.589542 [ 3456 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:46.696688 [ 3447 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:46.830527 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:46.936319 [ 3451 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:47.028153 [ 3533 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:47.297733 [ 3423 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:47.367924 [ 3432 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:47.387107 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:47.590685 [ 3422 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:47.697861 [ 3413 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:47.911391 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:47.937252 [ 3412 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:48.029695 [ 3410 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:48.298898 [ 3409 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:48.368798 [ 3405 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:48.417191 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:48.592186 [ 3392 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:48.661315 [ 3645 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {26a86919-b755-436d-800b-c04857d425d1::202510_1_126_58}: 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 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) @ 0x0000000039c89948 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000003999bfb7 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 @ 0x00000000399942f0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000039d15c04 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&) @ 0x0000000039d20399 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) @ 0x0000000039d1c606 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000396308a4 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x00000000396235dd 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000003963b3e0 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x00000000396504a0 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3c455d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:48.698718 [ 3387 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:48.938240 [ 3388 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:48.945281 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:49.030887 [ 3381 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:49.300059 [ 3375 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:49.369609 [ 3370 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:49.457192 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:49.593102 [ 3371 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:49.699528 [ 3379 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:49.939068 [ 3360 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:50.004385 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:50.031792 [ 3351 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:50.300975 [ 3363 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:50.370488 [ 3373 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:50.523344 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:50.594102 [ 3352 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:50.700799 [ 3337 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:50.939965 [ 3355 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:51.032791 [ 3372 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:51.040525 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:51.248133 [ 2903 ] {338ae9a2-bcc2-4f1f-aeda-d7737b034ec2} DB::ConcurrentHashJoin::ConcurrentHashJoin(ContextPtr, std::shared_ptr, size_t, const Block &, const StatsCollectingParams &, bool): 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202dea34 6. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:0: DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, std::shared_ptr, unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool) @ 0x0000000034775418 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr&, std::shared_ptr&, DB::SettingFieldMaxThreads const&, DB::Block const&, DB::StatsCollectingParams&, void>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::SettingFieldMaxThreads const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x0000000034df93df 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000034debf55 9. ./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&) @ 0x0000000034d95d85 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d6a797 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0b8de 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cfd8b2 13. ./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) @ 0x0000000034d74f61 14. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1777: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d67094 15. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0b8de 16. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cfd8b2 17. ./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) @ 0x0000000034d74f61 18. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1777: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d67094 19. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0b8de 20. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cfd8b2 21. ./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) @ 0x0000000034d74f61 22. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1777: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d67094 23. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0b8de 24. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cfd8b2 25. ./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) @ 0x0000000034d74f61 26. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1777: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d67094 27. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0b8de 28. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cfd8b2 29. ./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) @ 0x0000000034d74f61 30. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1777: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d67094 31. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0b8de (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:51.301835 [ 3334 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:51.371247 [ 3327 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:51.455890 [ 2903 ] {338ae9a2-bcc2-4f1f-aeda-d7737b034ec2} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42126) (comment: 00632_get_sample_block_cache.sql) (in query: --SELECT `entityIri`, `watchers-count`, `time-repeating-average`, `reject-views-duration-average`, `repeating-views-count-average`, `views-duration-average`, `watched-part-average`, `rejects-count`, `progress-average`, `views-count-before-full-watched-average`, `duration`, `full-watched-learners-count`, `overall-watchers-count`, `overall-full-watched-learners-count`, `views-count`, `time-before-full-watched-average`, if (isNaN((`overall-full-watched-learners-count`/`overall-watchers-count`) * 100), 0, (`overall-full-watched-learners-count`/`overall-watchers-count`) * 100) as `overall-watched-part`, if (isNaN((`full-watched-learners-count`/`watchers-count` * 100)), 0, (`full-watched-learners-count`/`watchers-count` * 100)) as `full-watched-part`, if (isNaN((`rejects-count`/`views-count` * 100)), 0, (`rejects-count`/`views-count` * 100)) as `rejects-part` FROM (SELECT `entityIri`, `watchers-count`, `time-repeating-average`, `reject-views-duration-average`, `repeating-views-count-average`, `views-duration-average`, `watched-part-average`, `rejects-count`, `progress-average`, `views-count-before-full-watched-average`, `duration`, `full-watched-learners-count`, `overall-watchers-count`, `overall-full-watched-learners-count`, `views-count`, `time-before-full-watched-average` FROM (SELECT `entityIri`, `watchers-count`, `time-repeating-average`, `reject-views-duration-average`, `repeating-views-count-average`, `views-duration-average`, `watched-part-average`, `rejects-count`, `progress-average`, `views-count-before-full-watched-average`, `duration`, `full-watched-learners-count`, `overall-watchers-count`, `overall-full-watched-learners-count`, `views-count` FROM (SELECT `entityIri`, `watchers-count`, `time-repeating-average`, `reject-views-duration-average`, `repeating-views-count-average`, `views-duration-average`, `watched-part-average`, `rejects-count`, `progress-average`, `views-count-before-full-watched-average`, `duration`, `full-watched-learners-count`, `overall-watchers-count`, `overall-full-watched-learners-count` FROM (SELECT `entityIri`, `watchers-count`, `time-repeating-average`, `reject-views-duration-average`, `repeating-views-count-average`, `views-duration-average`, `watched-part-average`, `rejects-count`, `progress-average`, `views-count-before-full-watched-average`, `duration`, `full-watched-learners-count`, `overall-watchers-count` FROM (SELECT `entityIri`, `watchers-count`, `time-repeating-average`, `reject-views-duration-average`, `repeating-views-count-average`, `views-duration-average`, `watched-part-average`, `rejects-count`, `progress-average`, `views-count-before-full-watched-average`, `duration`, `full-watched-learners-count` FROM (SELECT `entityIri`, `watchers-count`, `time-repeating-average`, `reject-views-duration-average`, `repeating-views-count-average`, `views-duration-average`, `watched-part-average`, `rejects-count`, `progress-average`, `views-count-before-full-watched-average`, `duration` FROM (SELECT `entityIri`, `watchers-count`, `time-repeating-average`, `reject-views-duration-average`, `repeating-views-count-average`, `views-duration-average`, `watched-part-average`, `rejects-count`, `progress-average`, `views-count-before-full-watched-average` FROM (SELECT `entityIri`, `watchers-count`, `time-repeating-average`, `reject-views-duration-average`, `repeating-views-count-average`, `views-duration-average`, `watched-part-average`, `rejects-count`, `progress-average` FROM (SELECT `entityIri`, `watchers-count`, `time-repeating-average`, `reject-views-duration-average`, `repeating-views-count-average`, `views-duration-average`, `watched-part-average`, `rejects-count` FROM (SELECT `entityIri`, `watchers-count`, `time-repeating-average`, `reject-views-duration-average`, `repeating-views-count-average`, `views-duration-average`, `watched-part-average` FROM (SELECT `entityIri`, `watchers-count`, `time-repeating-average`, `reject-views-duration-average`, `repeating-views-count-average`, `views-duration-average` FROM (SELECT `entityIri`, `watchers-count`, `time-repeating-average`, `reject-views-duration-average`, `repeating-views-count-average` FROM (SELECT `entityIri`, `watchers-count`, `time-repeating-average`, `reject-views-duration-average` FROM (SELECT `entityIri`, `watchers-count`, `time-repeating-average` FROM (SELECT `entityIri`, `watchers-count` FROM (SELECT `entityIri` FROM `CloM8CwMR2`) ANY LEFT JOIN (SELECT uniq(learnerId) as `watchers-count`, `entityIri` FROM `video_views` FINAL ARRAY JOIN `views` PREWHERE `entityIri` IN `CloM8CwMR2` AND `courseId` = 1 WHERE `learnerId` IN `tkRpHxGqM1` GROUP BY `entityIri`) USING `entityIri`) ANY LEFT JOIN (SELECT avg(viewDurationSum) as `time-repeating-average`, `entityIri` FROM (SELECT sum(views.viewDuration) as viewDurationSum, `entityIri`, `learnerId` FROM `video_views` FINAL ARRAY JOIN `views` PREWHERE `entityIri` IN `CloM8CwMR2` AND `courseId` = 1 WHERE `views`.`repeatingView` = 1 AND `learnerId` IN `tkRpHxGqM1` GROUP BY `learnerId`, `entityIri`) GROUP BY `entityIri`) USING `entityIri`) ANY LEFT JOIN (SELECT avg(views.viewDuration) as `reject-views-duration-average`, `entityIri` FROM `video_views` FINAL ARRAY JOIN `views` PREWHERE `entityIri` IN `CloM8CwMR2` AND `courseId` = 1 WHERE `views`.`reject` = 1 AND `learnerId` IN `tkRpHxGqM1` GROUP BY `entityIri`) USING `entityIri`) ANY LEFT JOIN (SELECT avg(viewsCount) as `repeating-views-count-average`, `entityIri` FROM (SELECT count() as viewsCount, `learnerId`, `entityIri` FROM `video_views` FINAL ARRAY JOIN `views` PREWHERE `courseId` = 1 AND `entityIri` IN `CloM8CwMR2` WHERE `views`.`repeatingView` = 1 AND `learnerId` IN `tkRpHxGqM1` GROUP BY `learnerId`, `entityIri`) GROUP BY `entityIri`) USING `entityIri`) ANY LEFT JOIN (SELECT avg(views.viewDuration) as `views-duration-average`, `entityIri` FROM `video_views` FINAL ARRAY JOIN `views` PREWHERE `entityIri` IN `CloM8CwMR2` AND `courseId` = 1 WHERE `learnerId` IN `tkRpHxGqM1` GROUP BY `entityIri`) USING `entityIri`) ANY LEFT JOIN (SELECT avg(views.watchedPart) as `watched-part-average`, `entityIri` FROM `video_views` FINAL ARRAY JOIN `views` PREWHERE `entityIri` IN `CloM8CwMR2` AND `courseId` = 1 WHERE `learnerId` IN `tkRpHxGqM1` GROUP BY `entityIri`) USING `entityIri`) ANY LEFT JOIN (SELECT count() as `rejects-count`, `entityIri` FROM `video_views` FINAL ARRAY JOIN `views` PREWHERE `entityIri` IN `CloM8CwMR2` AND `courseId` = 1 WHERE `views`.`reject` = 1 AND `learnerId` IN `tkRpHxGqM1` GROUP BY `entityIri`) USING `entityIri`) ANY LEFT JOIN (SELECT avg(progressMax) as `progress-average`, `entityIri` FROM (SELECT max(views.progress) as progressMax, `entityIri`, `learnerId` FROM `video_views` FINAL ARRAY JOIN `views` PREWHERE `entityIri` IN `CloM8CwMR2` AND `courseId` = 1 WHERE `learnerId` IN `tkRpHxGqM1` GROUP BY `learnerId`, `entityIri`) GROUP BY `entityIri`) USING `entityIri`) ANY LEFT JOIN (SELECT avg(fullWatchedViews) as `views-count-before-full-watched-average`, `entityIri` FROM `video_views` FINAL PREWHERE `entityIri` IN `CloM8CwMR2` AND `courseId` = 1 WHERE `learnerId` IN `tkRpHxGqM1` GROUP BY `entityIri`) USING `entityIri`) ANY LEFT JOIN (SELECT any(duration) as `duration`, `entityIri` FROM `video_views` FINAL PREWHERE `entityIri` IN `CloM8CwMR2` AND `courseId` = 1 WHERE `learnerId` IN `tkRpHxGqM1` GROUP BY `entityIri`) USING `entityIri`) ANY LEFT JOIN (SELECT uniq(learnerId) as `full-watched-learners-count`, `entityIri` FROM `video_views` FINAL PREWHERE `entityIri` IN `CloM8CwMR2` AND `courseId` = 1 WHERE `fullWatched` = 1 AND `learnerId` IN `tkRpHxGqM1` GROUP BY `entityIri`) USING `entityIri`) ANY LEFT JOIN (SELECT uniq(learnerId) as `overall-watchers-count`, `entityIri` FROM `video_views` FINAL ARRAY JOIN `views` PREWHERE `entityIri` IN `CloM8CwMR2` AND `courseId` = 1 WHERE `learnerId` IN `tkRpHxGqM1` GROUP BY `entityIri`) USING `entityIri`) ANY LEFT JOIN (SELECT uniq(learnerId) as `overall-full-watched-learners-count`, `entityIri` FROM `video_views` FINAL PREWHERE `entityIri` IN `CloM8CwMR2` AND `courseId` = 1 WHERE `fullWatched` = 1 AND `learnerId` IN `tkRpHxGqM1` GROUP BY `entityIri`) USING `entityIri`) ANY LEFT JOIN (SELECT count() as `views-count`, `entityIri` FROM `video_views` FINAL ARRAY JOIN `views` PREWHERE `entityIri` IN `CloM8CwMR2` AND `courseId` = 1 WHERE `learnerId` IN `tkRpHxGqM1` GROUP BY `entityIri`) USING `entityIri`) ANY LEFT JOIN (SELECT avg(fullWatchedTime) as `time-before-full-watched-average`, `entityIri` FROM `video_views` FINAL PREWHERE `entityIri` IN `CloM8CwMR2` AND `courseId` = 1 WHERE `learnerId` IN `tkRpHxGqM1` GROUP BY `entityIri`) USING `entityIri`) FORMAT JSON; SELECT `entityIri`, `watchers-count`, `time-repeating-average`, `reject-views-duration-average`, `repeating-views-count-average`, `views-duration-average`, `watched-part-average`, `rejects-count`, `progress-average`, `views-count-before-full-watched-average`, `duration`, `full-watched-learners-count`, `overall-watchers-count`, `overall-full-watched-learners-count`, `views-count`, `time-before-full-watched-average`, if (isNaN((`overall-full-watched-learners-count`/`overall-watchers-count`) * 100), 0, (`overall-full-watched-learners-count`/`overall-watchers-count`) * 100) as `overall-watched-part`, if (isNaN((`full-watched-learners-count`/`watchers-count` * 100)), 0, (`full-watched-learners-count`/`watchers-count` * 100)) as `full-watched-part`, if (isNaN((`rejects-count`/`views-count` * 100)), 0, (`rejects-count`/`views-count` * 100)) as `rejects-part` FROM (SELECT `entityIri`, `watchers-count`, `time-repeating-average`, `reject-views-duration-average`, `repeating-views-count-average`, `views-duration-average`, `watched-part-average`, `rejects-count`, `progress-average`, `views-count-before-full-watched-average`, `duration`, `full-watched-learners-count`, `overall-watchers-count`, `overall-full-watched-learners-count`, `views-count`, `time-before-full-watched-average` FROM (SELECT `entityIri`, `watchers-count`, `time-repeating-average`, `reject-views-duration-average`, `repeating-views-count-average`, `views-duration-average`, `watched-part-average`, `rejects-count`, `progress-average`, `views-count-before-full-watched-average`, `duration`, `full-watched-learners-count`, `overall-watchers-count`, `overall-full-watched-learners-count`, `views-count` FROM (SELECT `entityIri`, `watchers-count`, `time-repeating-average`, `reject-views-duration-average`, `repeating-views-count-average`, `views-duration-average`, `watched-part-average`, `rejects-count`, `progress-average`, `views-count-before-full-watched-average`, `duration`, `full-watched-learners-count`, `overall-watchers-count`, `overall-full-watched-learners-count` FROM (SELECT `entityIri`, `watchers-count`, `time-repeating-average`, `reject-views-duration-average`, `repeating-views-count-average`, `views-duration-average`, `watched-part-average`, `rejects-count`, `progress-average`, `views-count-before-full-watched-average`, `duration`, `full-watched-learners-count`, `overall-watchers-count` FROM (SELECT `entityIri`, `watchers-count`, `time-repeating-average`, `reject-views-duration-average`, `repeating-views-count-average`, `views-duration-average`, `watched-part-average`, `rejects-count`, `progress-average`, `views-count-before-full-watched-average`, `duration`, `full-watched-learners-count` FROM (SELECT `entityIri`, `watchers-count`, `time-repeating-average`, `reject-views-duration-average`, `repeating-views-count-average`, `views-duration-average`, `watched-part-average`, `rejects-count`, `progress-average`, `views-count-before-full-watched-average`, `duration` FROM (SELECT `entityIri`, `watchers-count`, `time-repeating-average`, `reject-views-duration-average`, `repeating-views-count-average`, `views-duration-average`, `watched-part-average`, `rejects-count`, `progress-average`, `views-count-before-full-watched-average` FROM (SELECT `entityIri`, `watchers-count`, `time-repeating-average`, `reject-views-duration-average`, `repeating-views-count-average`, `views-duration-average`, `watched-part-average`, `rejects-count`, `progress-average` FROM (SELECT `entityIri`, `watchers-count`, `time-repeating-average`, `reject-views-duration-average`, `repeating-views-count-average`, `views-duration-average`, `watched-part-average`, `rejects-count` FROM (SELECT `entityIri`, `watchers-count`, `time-repeating-average`, `reject-views-duration-average`, `repeating-views-count-average`, `views-duration-average`, `watched-part-average` FROM (SELECT `entityIri`, `watchers-count`, `time-repeating-average`, `reject-views-duration-average`, `repeating-views-count-average`, `views-duration-average` FROM (SELECT `entityIri`, `watchers-count`, `time-repeating-average`, `reject-views-duration-average`, `repeating-views-count-average` FROM (SELECT `entityIri`, `watchers-count`, `time-repeating-average`, `reject-views-duration-average` FROM (SELECT `entityIri`, `watchers-count`, `time-repeating-average` FROM (SELECT `entityIri`, `watchers-count` FROM (SELECT `entityIri` FROM dict_string) ANY LEFT JOIN (SELECT uniq(learnerId) as `watchers-count`, `entityIri` FROM `video_views` FINAL ARRAY JOIN `views` PREWHERE `entityIri` IN dict_string AND `courseId` = 1 WHERE `learnerId` IN dict_ui64 GROUP BY `entityIri`) USING `entityIri`) ANY LEFT JOIN (SELECT avg(viewDurationSum) as `time-repeating-average`, `entityIri` FROM (SELECT sum(views.viewDuration) as viewDurationSum, `entityIri`, `learnerId` FROM `video_views` FINAL ARRAY JOIN `views` PREWHERE `entityIri` IN dict_string AND `courseId` = 1 WHERE `views`.`repeatingView` = 1 AND `learnerId` IN dict_ui64 GROUP BY `learnerId`, `entityIri`) GROUP BY `entityIri`) USING `entityIri`) ANY LEFT JOIN (SELECT avg(views.viewDuration) as `reject-views-duration-average`, `entityIri` FROM `video_views` FINAL ARRAY JOIN `views` PREWHERE `entityIri` IN dict_string AND `courseId` = 1 WHERE `views`.`reject` = 1 AND `learnerId` IN dict_ui64 GROUP BY `entityIri`) USING `entityIri`) ANY LEFT JOIN (SELECT avg(viewsCount) as `repeating-views-count-average`, `entityIri` FROM (SELECT count() as viewsCount, `learnerId`, `entityIri` FROM `video_views` FINAL ARRAY JOIN `views` PREWHERE `courseId` = 1 AND `entityIri` IN dict_string WHERE `views`.`repeatingView` = 1 AND `learnerId` IN dict_ui64 GROUP BY `learnerId`, `entityIri`) GROUP BY `entityIri`) USING `entityIri`) ANY LEFT JOIN (SELECT avg(views.viewDuration) as `views-duration-average`, `entityIri` FROM `video_views` FINAL ARRAY JOIN `views` PREWHERE `entityIri` IN dict_string AND `courseId` = 1 WHERE `learnerId` IN dict_ui64 GROUP BY `entityIri`) USING `entityIri`) ANY LEFT JOIN (SELECT avg(views.watchedPart) as `watched-part-average`, `entityIri` FROM `video_views` FINAL ARRAY JOIN `views` PREWHERE `entityIri` IN dict_string AND `courseId` = 1 WHERE `learnerId` IN dict_ui64 GROUP BY `entityIri`) USING `entityIri`) ANY LEFT JOIN (SELECT count() as `rejects-count`, `entityIri` FROM `video_views` FINAL ARRAY JOIN `views` PREWHERE `entityIri` IN dict_string AND `courseId` = 1 WHERE `views`.`reject` = 1 AND `learnerId` IN dict_ui64 GROUP BY `entityIri`) USING `entityIri`) ANY LEFT JOIN (SELECT avg(progressMax) as `progress-average`, `entityIri` FROM (SELECT max(views.progress) as progressMax, `entityIri`, `learnerId` FROM `video_views` FINAL ARRAY JOIN `views` PREWHERE `entityIri` IN dict_string AND `courseId` = 1 WHERE `learnerId` IN dict_ui64 GROUP BY `learnerId`, `entityIri`) GROUP BY `entityIri`) USING `entityIri`) ANY LEFT JOIN (SELECT avg(fullWatchedViews) as `views-count-before-full-watched-average`, `entityIri` FROM `video_views` FINAL PREWHERE `entityIri` IN dict_string AND `courseId` = 1 WHERE `learnerId` IN dict_ui64 GROUP BY `entityIri`) USING `entityIri`) ANY LEFT JOIN (SELECT any(duration) as `duration`, `entityIri` FROM `video_views` FINAL PREWHERE `entityIri` IN dict_string AND `courseId` = 1 WHERE `learnerId` IN dict_ui64 GROUP BY `entityIri`) USING `entityIri`) ANY LEFT JOIN (SELECT uniq(learnerId) as `full-watched-learners-count`, `entityIri` FROM `video_views` FINAL PREWHERE `entityIri` IN dict_string AND `courseId` = 1 WHERE `fullWatched` = 1 AND `learnerId` IN dict_ui64 GROUP BY `entityIri`) USING `entityIri`) ANY LEFT JOIN (SELECT uniq(learnerId) as `overall-watchers-count`, `entityIri` FROM `video_views` FINAL ARRAY JOIN `views` PREWHERE `entityIri` IN dict_string AND `courseId` = 1 WHERE `learnerId` IN dict_ui64 GROUP BY `entityIri`) USING `entityIri`) ANY LEFT JOIN (SELECT uniq(learnerId) as `overall-full-watched-learners-count`, `entityIri` FROM `video_views` FINAL PREWHERE `entityIri` IN dict_string AND `courseId` = 1 WHERE `fullWatched` = 1 AND `learnerId` IN dict_ui64 GROUP BY `entityIri`) USING `entityIri`) ANY LEFT JOIN (SELECT count() as `views-count`, `entityIri` FROM `video_views` FINAL ARRAY JOIN `views` PREWHERE `entityIri` IN dict_string AND `courseId` = 1 WHERE `learnerId` IN dict_ui64 GROUP BY `entityIri`) USING `entityIri`) ANY LEFT JOIN (SELECT avg(fullWatchedTime) as `time-before-full-watched-average`, `entityIri` FROM `video_views` FINAL PREWHERE `entityIri` IN dict_string AND `courseId` = 1 WHERE `learnerId` IN dict_ui64 GROUP BY `entityIri`) USING `entityIri`);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202dea34 6. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:0: DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, std::shared_ptr, unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool) @ 0x0000000034775418 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr&, std::shared_ptr&, DB::SettingFieldMaxThreads const&, DB::Block const&, DB::StatsCollectingParams&, void>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::SettingFieldMaxThreads const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x0000000034df93df 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000034debf55 9. ./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&) @ 0x0000000034d95d85 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d6a797 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0b8de 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cfd8b2 13. ./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) @ 0x0000000034d74f61 14. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1777: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d67094 15. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0b8de 16. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cfd8b2 17. ./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) @ 0x0000000034d74f61 18. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1777: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d67094 19. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0b8de 20. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cfd8b2 21. ./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) @ 0x0000000034d74f61 22. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1777: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d67094 23. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0b8de 24. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cfd8b2 25. ./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) @ 0x0000000034d74f61 26. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1777: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d67094 27. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0b8de 28. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cfd8b2 29. ./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) @ 0x0000000034d74f61 30. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1777: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d67094 31. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0b8de 2025.10.23 23:45:51.464611 [ 2903 ] {338ae9a2-bcc2-4f1f-aeda-d7737b034ec2} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202dea34 6. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:0: DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, std::shared_ptr, unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool) @ 0x0000000034775418 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr&, std::shared_ptr&, DB::SettingFieldMaxThreads const&, DB::Block const&, DB::StatsCollectingParams&, void>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::SettingFieldMaxThreads const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x0000000034df93df 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000034debf55 9. ./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&) @ 0x0000000034d95d85 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d6a797 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0b8de 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cfd8b2 13. ./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) @ 0x0000000034d74f61 14. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1777: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d67094 15. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0b8de 16. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cfd8b2 17. ./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) @ 0x0000000034d74f61 18. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1777: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d67094 19. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0b8de 20. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cfd8b2 21. ./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) @ 0x0000000034d74f61 22. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1777: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d67094 23. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0b8de 24. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cfd8b2 25. ./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) @ 0x0000000034d74f61 26. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1777: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d67094 27. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0b8de 28. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cfd8b2 29. ./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) @ 0x0000000034d74f61 30. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1777: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d67094 31. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0b8de 2025.10.23 23:45:51.572735 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:51.594969 [ 3348 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:51.701928 [ 3341 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:51.941040 [ 3315 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:52.033722 [ 3320 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:52.101184 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:52.171036 [ 3649 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b37203c3-8fb0-4cdf-8555-9946d278f55b::202510_86_116_6}: 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 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) @ 0x0000000039c89948 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000003999bfb7 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 @ 0x00000000399942f0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000039d15c04 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&) @ 0x0000000039d20399 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) @ 0x0000000039d1c606 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000396308a4 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x00000000396235dd 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000003963b3e0 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x00000000396504a0 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3c455d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:52.303079 [ 3301 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:52.372508 [ 3313 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:52.456165 [ 4841 ] {1de16517-7783-4bd7-a2b4-8a3479060201} executeQuery: Code: 57. DB::Exception: Table test_1.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:53858) (comment: 02723_zookeeper_name.sql) (in query: CREATE TABLE t1 (`k` UInt32, `v` UInt32) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/test_02723/zookeeper_name/t1', '1') ORDER BY k SETTINGS index_granularity = 3269, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 117745276, compact_parts_max_bytes_to_buffer = 356084530, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 17840461, merge_max_block_size = 24401, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 338970, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 29544693, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 81824, primary_key_compress_block_size = 97111), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:45:52.460339 [ 4841 ] {1de16517-7783-4bd7-a2b4-8a3479060201} TCPHandler: Code: 57. DB::Exception: Table test_1.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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:45:52.596105 [ 3303 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:52.636723 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:52.702899 [ 3300 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:52.942130 [ 3299 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:53.034734 [ 3290 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:53.190176 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:53.304801 [ 3283 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:53.373411 [ 3272 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:53.597054 [ 3269 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:53.704281 [ 3267 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:53.731407 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:53.943419 [ 3264 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:54.035974 [ 3255 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:54.256906 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:54.305871 [ 3262 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:54.374418 [ 3271 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:54.598116 [ 3254 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:54.705530 [ 3244 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:54.820134 [ 3894 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:54.944941 [ 3245 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:55.037102 [ 3235 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:55.306765 [ 3231 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:55.350985 [ 3894 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:55.375298 [ 3237 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:55.599075 [ 3220 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:55.706584 [ 3218 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:55.852946 [ 3894 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:55.945858 [ 3217 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:56.038363 [ 3212 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:56.307627 [ 3195 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:56.376350 [ 3205 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:56.382447 [ 3894 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:56.600242 [ 3188 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:56.707970 [ 3192 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:56.855972 [ 4841 ] {7ccc6c24-a461-4198-a2ac-f14eb65e32d7} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=6, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:53904) (comment: 02286_parallel_final.sh) (in query: explain pipeline select * from tbl_8parts_2granules_rnd final settings max_threads = 16, do_not_merge_across_partitions_select_final = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202dea34 6. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039a5dbc5 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003bf2b229 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bf26bba 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003bf26345 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bf3d5b9 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2045: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf42fe0 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be48783 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003beb6da5 14. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:513: DB::InterpreterExplainQuery::executeImpl() @ 0x000000003495cb4c 15. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:0: DB::InterpreterExplainQuery::execute() @ 0x00000000349520a4 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:45:56.858216 [ 4841 ] {7ccc6c24-a461-4198-a2ac-f14eb65e32d7} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=6, 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202dea34 6. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039a5dbc5 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003bf2b229 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bf26bba 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003bf26345 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bf3d5b9 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2045: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf42fe0 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be48783 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003beb6da5 14. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:513: DB::InterpreterExplainQuery::executeImpl() @ 0x000000003495cb4c 15. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:0: DB::InterpreterExplainQuery::execute() @ 0x00000000349520a4 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:45:56.894619 [ 3894 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:56.946632 [ 3185 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:57.039388 [ 3183 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:57.308928 [ 3171 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:57.377436 [ 3170 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:57.498035 [ 3894 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:57.601205 [ 3167 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:57.709436 [ 3166 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:57.922869 [ 3894 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:57.947525 [ 3161 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:58.030832 [ 3645 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {26a86919-b755-436d-800b-c04857d425d1::202510_1_127_59}: 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000002009b98d 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x000000002009675f 5. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:129: CurrentMemoryTracker::injectFault() @ 0x000000001ff7d1df 6. ./build_docker/./src/Common/ThreadFuzzer.cpp:270: DB::ThreadFuzzer::maybeInjectMemoryLimitException() @ 0x000000002011909f 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:151: DB::MergePlainMergeTreeTask::finish() @ 0x000000003a3c7732 8. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3c4534 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:58.040372 [ 3139 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:58.310036 [ 3144 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:58.378279 [ 3133 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:58.596242 [ 3894 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:58.601975 [ 3126 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:58.710765 [ 3128 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:58.948584 [ 3131 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:59.013008 [ 3894 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:59.041268 [ 3125 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:59.311571 [ 3132 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:59.379170 [ 3127 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:59.602897 [ 3117 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:59.648044 [ 3894 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:45:59.712437 [ 3122 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:59.949539 [ 3090 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:00.042346 [ 3089 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:00.077485 [ 3894 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:00.313283 [ 3083 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:00.389436 [ 3076 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:00.603819 [ 3084 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:00.713850 [ 3086 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:00.714326 [ 3894 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:00.950466 [ 3070 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:01.043467 [ 3059 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:01.124307 [ 3894 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:01.314462 [ 3062 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:01.390571 [ 3066 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:01.604717 [ 3069 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:01.715022 [ 3054 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:01.776799 [ 3894 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:01.843828 [ 4841 ] {61870dd8-5759-40a9-8360-22b6978e8651} executeQuery: Code: 241. DB::Exception: Memory tracker (for thread): fault injected (at specific point). (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:33088) (comment: 02286_parallel_final.sh) (in query: optimize table tbl_8parts_3granules_rnd final;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000002009b98d 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x000000002009675f 5. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:129: CurrentMemoryTracker::injectFault() @ 0x000000001ff7d1df 6. ./build_docker/./src/Common/ThreadFuzzer.cpp:270: DB::ThreadFuzzer::maybeInjectMemoryLimitException() @ 0x000000002011909f 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:151: DB::MergePlainMergeTreeTask::finish() @ 0x000000003a3c7732 8. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3c4534 9. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:104: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x000000003a318b63 10. ./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) @ 0x000000003a32e805 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterOptimizeQuery::execute() @ 0x00000000359d3851 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 21. ? @ 0x00007f100c857ac3 22. ? @ 0x00007f100c8e9850 2025.10.23 23:46:01.846796 [ 4841 ] {61870dd8-5759-40a9-8360-22b6978e8651} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000002009b98d 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x000000002009675f 5. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:129: CurrentMemoryTracker::injectFault() @ 0x000000001ff7d1df 6. ./build_docker/./src/Common/ThreadFuzzer.cpp:270: DB::ThreadFuzzer::maybeInjectMemoryLimitException() @ 0x000000002011909f 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:151: DB::MergePlainMergeTreeTask::finish() @ 0x000000003a3c7732 8. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3c4534 9. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:104: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x000000003a318b63 10. ./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) @ 0x000000003a32e805 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterOptimizeQuery::execute() @ 0x00000000359d3851 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 21. ? @ 0x00007f100c857ac3 22. ? @ 0x00007f100c8e9850 2025.10.23 23:46:01.951512 [ 3396 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:02.044694 [ 3443 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:02.155325 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:02.315527 [ 3345 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:02.391593 [ 3406 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:02.605553 [ 3063 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:02.716187 [ 3141 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:02.832713 [ 3894 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:02.990094 [ 3174 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:03.045720 [ 3563 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:03.216985 [ 3894 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:03.316692 [ 3564 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:03.392585 [ 3560 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:03.606378 [ 3559 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:03.717127 [ 3565 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:03.893726 [ 3894 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:03.991134 [ 3553 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:04.046726 [ 3545 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:04.237976 [ 3894 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:04.317609 [ 3548 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:04.393507 [ 3554 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:04.607336 [ 3519 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:04.718042 [ 3537 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:04.936318 [ 3894 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:04.992193 [ 3515 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:05.047843 [ 3518 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:05.258861 [ 3894 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:05.318776 [ 3513 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:05.394459 [ 3507 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:05.608520 [ 3499 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:05.719259 [ 3502 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:05.993055 [ 3498 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:06.016335 [ 3894 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:06.048833 [ 3493 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:06.288187 [ 3894 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:06.320378 [ 3486 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:06.395371 [ 3479 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:06.609389 [ 3489 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:06.720373 [ 3480 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:06.994243 [ 3466 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:07.049839 [ 3462 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:07.061086 [ 3894 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:07.307540 [ 3894 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:07.321517 [ 3458 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:07.396494 [ 3470 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:07.610129 [ 3464 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:07.721372 [ 3439 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:07.995163 [ 3456 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:08.050777 [ 3442 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:08.148480 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:08.322541 [ 3441 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:08.370902 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:08.397416 [ 3438 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:08.610890 [ 3413 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:08.722562 [ 3424 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:08.996387 [ 3411 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:09.052186 [ 3407 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:09.233117 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:09.324271 [ 3395 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:09.398512 [ 3404 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:09.455568 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:09.612261 [ 3387 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:09.723962 [ 3389 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:09.997396 [ 3380 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:10.053596 [ 3378 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:10.326121 [ 3366 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:10.399607 [ 3376 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:10.323671 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:10.488834 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:10.613532 [ 3360 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:10.725450 [ 3358 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:10.998559 [ 3373 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:11.055242 [ 3349 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:11.327356 [ 3339 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:11.400831 [ 3337 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:11.499370 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:11.545249 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:11.614432 [ 3330 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:11.726702 [ 3323 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:11.999611 [ 3341 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:12.056718 [ 3324 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:12.328844 [ 3311 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:12.401915 [ 3314 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:12.569936 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:12.615472 [ 3317 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:12.628877 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:12.728070 [ 3304 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:13.001194 [ 3313 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:13.057952 [ 3297 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:13.329946 [ 3302 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:13.402815 [ 3292 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:13.616705 [ 3286 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:13.649464 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:13.693075 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:13.729188 [ 3278 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:14.002367 [ 3275 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:14.059094 [ 3276 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:14.330920 [ 3266 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:14.403618 [ 3274 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:14.617527 [ 3260 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:14.726965 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:14.730145 [ 3255 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:14.756150 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:15.003361 [ 3256 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:15.060469 [ 3249 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:15.332321 [ 3258 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:15.404776 [ 3245 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:15.618744 [ 3239 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:15.731454 [ 3234 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:15.788073 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:15.812665 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:16.004130 [ 3227 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:16.061713 [ 3232 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:16.333720 [ 3218 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:16.406546 [ 3214 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:16.619583 [ 3216 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:16.732764 [ 3211 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:16.849481 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:16.857431 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:17.005254 [ 3200 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:17.014766 [ 3894 ] {9218c147-f860-42b4-aadc-64a281e05024} executeQuery: Code: 241. DB::Exception: Memory tracker (for thread): fault injected (at specific point). (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:47042) (comment: 02286_parallel_final.sh) (in query: optimize table tbl_8parts_8granules_rnd final;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000002009b98d 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x000000002009675f 5. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:129: CurrentMemoryTracker::injectFault() @ 0x000000001ff7d1df 6. ./build_docker/./src/Common/ThreadFuzzer.cpp:270: DB::ThreadFuzzer::maybeInjectMemoryLimitException() @ 0x000000002011909f 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:151: DB::MergePlainMergeTreeTask::finish() @ 0x000000003a3c7732 8. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3c4534 9. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:104: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x000000003a318b63 10. ./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) @ 0x000000003a32e805 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterOptimizeQuery::execute() @ 0x00000000359d3851 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 21. ? @ 0x00007f100c857ac3 22. ? @ 0x00007f100c8e9850 2025.10.23 23:46:17.016986 [ 3894 ] {9218c147-f860-42b4-aadc-64a281e05024} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000002009b98d 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x000000002009675f 5. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:129: CurrentMemoryTracker::injectFault() @ 0x000000001ff7d1df 6. ./build_docker/./src/Common/ThreadFuzzer.cpp:270: DB::ThreadFuzzer::maybeInjectMemoryLimitException() @ 0x000000002011909f 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:151: DB::MergePlainMergeTreeTask::finish() @ 0x000000003a3c7732 8. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3c4534 9. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:104: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x000000003a318b63 10. ./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) @ 0x000000003a32e805 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterOptimizeQuery::execute() @ 0x00000000359d3851 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 21. ? @ 0x00007f100c857ac3 22. ? @ 0x00007f100c8e9850 2025.10.23 23:46:17.062564 [ 3198 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:17.335145 [ 3202 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:17.407531 [ 3195 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:17.620472 [ 3191 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:17.733834 [ 3186 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:17.931111 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:17.956044 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:18.006135 [ 3183 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:18.069437 [ 3182 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:18.336476 [ 3165 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:18.409091 [ 3169 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:18.621477 [ 3147 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:18.735237 [ 3154 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:18.862027 [ 3647 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {9a375c2d-1765-4ead-bc63-7dc0959ac450::202510_195_240_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 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) @ 0x0000000039c89948 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000003999bfb7 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 @ 0x00000000399942f0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000039d15c04 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&) @ 0x0000000039d20399 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) @ 0x0000000039d1c606 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000396308a4 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x00000000396235dd 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000003963b3e0 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x00000000396504a0 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3c455d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:18.961957 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:19.007199 [ 3137 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:19.070759 [ 3177 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:19.124274 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:19.338007 [ 3128 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:19.409916 [ 3121 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:19.622978 [ 3131 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:19.736854 [ 3130 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:20.008759 [ 3108 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:20.011144 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:20.072742 [ 3112 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:20.282291 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:20.339385 [ 3117 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:20.411094 [ 3122 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:20.624331 [ 3093 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:20.738074 [ 3087 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:21.009647 [ 3096 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:21.073844 [ 3071 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:21.076852 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:21.340881 [ 3078 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:21.378074 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:21.458803 [ 3079 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:21.625444 [ 3070 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:21.739283 [ 3058 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:22.010485 [ 3065 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:22.075011 [ 3056 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:22.104621 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:22.342173 [ 3427 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:22.456316 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:22.459975 [ 3433 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:22.626551 [ 3345 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:22.740690 [ 3236 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:23.011359 [ 3197 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:23.076274 [ 3141 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:23.155490 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:23.343321 [ 3563 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:23.460850 [ 3562 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:23.504952 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:23.627689 [ 3542 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:23.741826 [ 3111 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:24.012268 [ 3550 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:24.077371 [ 3552 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:24.288567 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:24.344325 [ 3535 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:24.462008 [ 3532 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:24.629083 [ 3558 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:24.718678 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:24.743034 [ 3530 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:25.013741 [ 3526 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:25.078514 [ 3549 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:25.330443 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:25.345442 [ 3547 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:25.463031 [ 3514 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:25.630135 [ 3509 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:25.744643 [ 3506 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:25.885610 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:26.014524 [ 3507 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:26.079446 [ 3500 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:26.346338 [ 3494 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:26.395521 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:26.464147 [ 3493 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:26.631162 [ 3481 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:26.745853 [ 3483 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:26.937192 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:27.015454 [ 3477 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:27.080838 [ 3469 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:27.347268 [ 3465 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:27.444491 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:27.464981 [ 3460 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:27.632294 [ 3459 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:27.747007 [ 3450 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:27.981847 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:28.016790 [ 3442 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:28.082052 [ 3434 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:28.348680 [ 3441 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:28.466156 [ 3432 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:28.468759 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:28.633446 [ 3422 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:28.748371 [ 3420 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:29.017913 [ 3421 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:29.022724 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:29.083168 [ 3411 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:29.350199 [ 3397 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:29.467453 [ 3408 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:29.520732 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:29.634767 [ 3384 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:29.749645 [ 3394 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:30.018781 [ 3380 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:30.072267 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:30.084247 [ 3369 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:30.351515 [ 3371 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:30.469199 [ 3376 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:30.592423 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:30.636056 [ 3362 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:30.751055 [ 3351 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:31.019914 [ 3349 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:31.085181 [ 3347 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:31.110850 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:31.352616 [ 3346 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:31.470137 [ 3326 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:31.626699 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:31.637161 [ 3325 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:31.663301 [ 2903 ] {356b9347-40a1-48eb-987f-68910b34de5d} executeQuery: Code: 241. DB::Exception: Memory tracker (for query): fault injected. Would use 8.49 MiB (attempt to allocate chunk of 1150784 bytes), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:55012) (comment: 02286_parallel_final.sh) (in query: insert into tbl_8parts_5granules_seq select number, 1 from numbers_mt(327680);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, String&&, long&, String&&) @ 0x000000002009baa7 4. ./build_docker/./src/Common/MemoryTracker.cpp:284: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002009a3d3 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099272 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7ca1d 7. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ff775a4 8. ./src/IO/BufferWithOwnMemory.h:130: DB::Memory>::alloc(unsigned long) @ 0x000000002018872a 9. ./src/IO/BufferWithOwnMemory.h:159: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000020205d13 10. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:102: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String) @ 0x0000000020203d2d 11. ./contrib/llvm-project/libcxx/include/string:1499: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long) @ 0x00000000205928a8 12. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15007] const&>(std::__fs::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&) @ 0x0000000032ed07c3 13. ./build_docker/./src/Disks/DiskLocal.cpp:0: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x0000000032eb8eb8 14. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x0000000032f0be03 15. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:137: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x00000000393c4ef1 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:249: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x00000000399e090e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:181: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, DB::MergeTreeIndexGranularity const&) @ 0x00000000399dfe3d 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:28: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, DB::MergeTreeIndexGranularity const&) @ 0x00000000399bda1e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, DB::MergeTreeIndexGranularity const&) @ 0x000000003999491e 20. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:179: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, DB::MergeTreeIndexGranularity const&) @ 0x00000000399da85d 21. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:53: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, DB::TransactionID, bool, bool, DB::WriteSettings const&, DB::MergeTreeIndexGranularity const&) @ 0x0000000039e3fbcf 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::NamesAndTypesList&, std::vector, std::allocator>>&, std::vector, std::allocator>>&, std::shared_ptr&, DB::TransactionID const&, bool, bool, DB::WriteSettings>(std::shared_ptr&, std::shared_ptr const&, DB::NamesAndTypesList&, std::vector, std::allocator>>&, std::vector, std::allocator>>&, std::shared_ptr&, DB::TransactionID const&, bool&&, bool&&, DB::WriteSettings&&) @ 0x0000000039f34c49 23. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:0: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039f1f5d9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:444: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039f1688a 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:0: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a3bda35 26. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bb51384 27. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b82a9a9 28. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b82a4b6 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b829167 30. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 2025.10.23 23:46:31.669973 [ 2903 ] {356b9347-40a1-48eb-987f-68910b34de5d} TCPHandler: Code: 241. DB::Exception: Memory tracker (for query): fault injected. Would use 8.49 MiB (attempt to allocate chunk of 1150784 bytes), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, String&&, long&, String&&) @ 0x000000002009baa7 4. ./build_docker/./src/Common/MemoryTracker.cpp:284: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002009a3d3 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099272 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7ca1d 7. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ff775a4 8. ./src/IO/BufferWithOwnMemory.h:130: DB::Memory>::alloc(unsigned long) @ 0x000000002018872a 9. ./src/IO/BufferWithOwnMemory.h:159: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000020205d13 10. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:102: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String) @ 0x0000000020203d2d 11. ./contrib/llvm-project/libcxx/include/string:1499: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long) @ 0x00000000205928a8 12. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15007] const&>(std::__fs::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&) @ 0x0000000032ed07c3 13. ./build_docker/./src/Disks/DiskLocal.cpp:0: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x0000000032eb8eb8 14. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x0000000032f0be03 15. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:137: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x00000000393c4ef1 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:249: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x00000000399e090e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:181: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, DB::MergeTreeIndexGranularity const&) @ 0x00000000399dfe3d 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:28: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, DB::MergeTreeIndexGranularity const&) @ 0x00000000399bda1e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, DB::MergeTreeIndexGranularity const&) @ 0x000000003999491e 20. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:179: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, DB::MergeTreeIndexGranularity const&) @ 0x00000000399da85d 21. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:53: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, DB::TransactionID, bool, bool, DB::WriteSettings const&, DB::MergeTreeIndexGranularity const&) @ 0x0000000039e3fbcf 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::NamesAndTypesList&, std::vector, std::allocator>>&, std::vector, std::allocator>>&, std::shared_ptr&, DB::TransactionID const&, bool, bool, DB::WriteSettings>(std::shared_ptr&, std::shared_ptr const&, DB::NamesAndTypesList&, std::vector, std::allocator>>&, std::vector, std::allocator>>&, std::shared_ptr&, DB::TransactionID const&, bool&&, bool&&, DB::WriteSettings&&) @ 0x0000000039f34c49 23. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:0: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039f1f5d9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:444: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039f1688a 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:0: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a3bda35 26. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bb51384 27. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b82a9a9 28. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b82a4b6 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b829167 30. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 2025.10.23 23:46:31.752558 [ 3372 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:32.020818 [ 3335 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:32.086162 [ 3315 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:32.158504 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:32.353900 [ 3318 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:32.471251 [ 3304 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:32.638379 [ 3301 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:32.754114 [ 3313 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:32.754477 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:33.022002 [ 3308 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:33.087109 [ 3302 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:33.333740 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:33.355389 [ 3286 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:33.472258 [ 3278 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:33.639387 [ 3279 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:33.755435 [ 3272 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:33.825833 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:33.894907 [ 9453 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x00000000315a10ad 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159da2f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b6b4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa269fb 10. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:34.022812 [ 3270 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:34.088172 [ 3266 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:34.356795 [ 3255 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:34.460821 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:34.473207 [ 3250 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:34.640512 [ 3243 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:34.756762 [ 3259 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:34.881835 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:35.023872 [ 3247 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:35.089290 [ 3233 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:35.357808 [ 3229 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:35.474040 [ 3228 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:35.507327 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:35.641500 [ 3214 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:35.757655 [ 3212 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:36.025045 [ 3219 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:36.028535 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:36.090588 [ 3200 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:36.360152 [ 3189 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:36.474879 [ 3191 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:36.552805 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:36.642519 [ 3186 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:36.758777 [ 3185 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:37.026352 [ 3175 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:37.085681 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:37.092257 [ 3171 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:37.361315 [ 3169 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:37.476097 [ 3161 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:37.643976 [ 3517 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:37.652631 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:37.760344 [ 3154 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:38.027435 [ 3134 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:38.093657 [ 3157 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:38.141946 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:38.362420 [ 3143 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:38.476959 [ 3121 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:38.644981 [ 3162 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:38.723996 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:38.761383 [ 3114 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:39.028291 [ 3120 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:39.094761 [ 3132 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:39.209422 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:39.363445 [ 3110 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:39.477804 [ 3097 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:39.645801 [ 3102 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:39.762514 [ 3100 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:39.771599 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:40.029006 [ 3083 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:40.095903 [ 3092 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:40.251286 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:40.459367 [ 3078 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:40.478971 [ 3072 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:40.646685 [ 3079 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:40.763506 [ 3104 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:40.954301 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:41.030025 [ 3069 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:41.097147 [ 3056 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:41.433480 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:41.460252 [ 3345 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:41.480055 [ 3418 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:41.647984 [ 3236 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:41.764812 [ 3265 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:42.031005 [ 3063 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:42.098189 [ 3197 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:42.190315 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:42.461491 [ 3564 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:42.481166 [ 3201 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:42.649224 [ 3560 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:42.766007 [ 3551 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:43.032499 [ 3550 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:43.099310 [ 3565 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:43.243362 [ 9453 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:43.462835 [ 3545 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:43.485258 [ 3529 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:43.650511 [ 3541 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:43.767118 [ 3530 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:44.033563 [ 3515 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:44.100716 [ 3518 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:44.174030 [ 4841 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x00000000315a10ad 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159da2f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b6b4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa269fb 10. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:44.308183 [ 2903 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:44.486312 [ 3503 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:44.511034 [ 3507 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:44.616199 [ 4841 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x00000000315a10ad 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159da2f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b6b4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa269fb 10. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:44.679653 [ 3500 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:44.768197 [ 3498 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:45.034371 [ 3484 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:45.101760 [ 3481 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:45.373396 [ 9453 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:45.487230 [ 3469 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:45.512545 [ 3472 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:45.681021 [ 3460 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:45.769376 [ 3461 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:46.035235 [ 3464 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:46.102949 [ 3453 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:46.432720 [ 9453 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:46.488207 [ 3447 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:46.513676 [ 3434 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:46.682110 [ 3533 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:46.770996 [ 3423 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:47.036269 [ 3432 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:47.104377 [ 3419 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:47.489146 [ 3412 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:47.506006 [ 9453 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:47.514826 [ 3417 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:47.683379 [ 3410 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:47.772657 [ 3421 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:47.804109 [ 2903 ] {5a727ecc-3778-467e-bbcc-46b3976db93c} 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.10542.altinitytest (altinity build)) (from [::1]:44492) (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char (&) [19]) @ 0x00000000201d768a 4. ./build_docker/./src/IO/ReadHelpers.cpp:0: void DB::readDateTimeTextFallback(long&, DB::ReadBuffer&, DateLUTImpl const&, char const*, char const*) @ 0x00000000201d67a0 5. void DB::readDateTimeTextImpl(long&, DB::ReadBuffer&, DateLUTImpl const&, char const*, char const*) @ 0x000000000962695d 6. 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&&) @ 0x0000000008e8bd95 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008e32549 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003345b0f4 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334edd21 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436960 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:46:47.806569 [ 2903 ] {5a727ecc-3778-467e-bbcc-46b3976db93c} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char (&) [19]) @ 0x00000000201d768a 4. ./build_docker/./src/IO/ReadHelpers.cpp:0: void DB::readDateTimeTextFallback(long&, DB::ReadBuffer&, DateLUTImpl const&, char const*, char const*) @ 0x00000000201d67a0 5. void DB::readDateTimeTextImpl(long&, DB::ReadBuffer&, DateLUTImpl const&, char const*, char const*) @ 0x000000000962695d 6. 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&&) @ 0x0000000008e8bd95 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008e32549 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003345b0f4 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334edd21 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436960 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:46:48.037208 [ 3401 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:48.105511 [ 3390 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:48.490277 [ 3377 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:48.516080 [ 3380 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:48.536193 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:48.684872 [ 3370 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:48.774107 [ 3366 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:49.038053 [ 3354 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:49.106661 [ 3349 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:49.491293 [ 3343 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:49.517053 [ 3350 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:49.623545 [ 9453 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:49.685699 [ 3365 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:49.775411 [ 3372 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:50.039377 [ 3323 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:50.146156 [ 3348 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:50.492581 [ 3311 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:50.517992 [ 3314 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:50.684682 [ 29264 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:50.686370 [ 3310 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:50.777009 [ 3306 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:51.040934 [ 3305 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:51.147402 [ 3297 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:51.493560 [ 3293 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:51.519118 [ 3312 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:51.687434 [ 3286 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:51.757176 [ 29264 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:51.778227 [ 3289 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:52.041721 [ 3282 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:52.148911 [ 3279 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:52.494371 [ 3276 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:52.520277 [ 3268 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:52.688610 [ 3270 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:52.779422 [ 3257 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:52.835563 [ 29264 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:53.042665 [ 3260 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:53.150226 [ 3262 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:53.495247 [ 3256 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:53.521391 [ 3259 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:53.689522 [ 3240 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:53.780843 [ 3245 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:53.797790 [ 4841 ] {38f510ef-20fb-4703-ae5c-6044b6f9c102} executeQuery: Code: 407. DB::Exception: Decimal convert overflow while multiplying 123456789000000000 by scale -6101065173709551616: In scope SELECT toDecimal64(toDecimal64('1234567890', 8), 10). (DECIMAL_OVERFLOW) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44452) (comment: 00700_decimal_casts_2.sql) (in query: SELECT toDecimal64(toDecimal64('1234567890', 8), 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000861f137 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:133: _ZN2DB19convertDecimalsImplINS_15DataTypeDecimalINS_7DecimalIlEEEES4_vQaa17IsDataTypeDecimalIT_E17IsDataTypeDecimalIT0_EEET1_RKNS5_9FieldTypeEjjRNS6_9FieldTypeE @ 0x00000000324e9e04 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:185: _ZN2DB15convertDecimalsINS_15DataTypeDecimalINS_7DecimalIlEEEES4_Qaa17IsDataTypeDecimalIT_E17IsDataTypeDecimalIT0_EEENS6_9FieldTypeERKNS5_9FieldTypeEjj @ 0x00000000324f4a9a 6. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000924492f 7. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000921d09f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:46:53.799599 [ 4841 ] {38f510ef-20fb-4703-ae5c-6044b6f9c102} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow while multiplying 123456789000000000 by scale -6101065173709551616: In scope SELECT toDecimal64(toDecimal64('1234567890', 8), 10). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000861f137 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:133: _ZN2DB19convertDecimalsImplINS_15DataTypeDecimalINS_7DecimalIlEEEES4_vQaa17IsDataTypeDecimalIT_E17IsDataTypeDecimalIT0_EEET1_RKNS5_9FieldTypeEjjRNS6_9FieldTypeE @ 0x00000000324e9e04 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:185: _ZN2DB15convertDecimalsINS_15DataTypeDecimalINS_7DecimalIlEEEES4_Qaa17IsDataTypeDecimalIT_E17IsDataTypeDecimalIT0_EEENS6_9FieldTypeERKNS5_9FieldTypeEjj @ 0x00000000324f4a9a 6. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000924492f 7. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000921d09f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:46:53.880996 [ 29264 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:54.043517 [ 3239 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:54.152117 [ 3233 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:54.496258 [ 3232 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:54.522663 [ 3220 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:54.690587 [ 3217 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:54.781853 [ 3211 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:54.913415 [ 29264 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:55.044594 [ 3206 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:55.153712 [ 3200 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:55.497008 [ 3202 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:55.524220 [ 3195 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:55.692093 [ 3189 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:55.782764 [ 3184 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:55.961982 [ 3894 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:56.045516 [ 3238 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:56.154924 [ 3187 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:56.497868 [ 3172 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:56.525283 [ 3171 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:56.693143 [ 3167 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:56.783575 [ 3153 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:57.004261 [ 3894 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:57.046517 [ 3161 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:57.156338 [ 3151 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:57.211760 [ 4841 ] {f70740b4-6b5b-453c-ba64-9172e6c8abe2} executeQuery: Code: 407. DB::Exception: Decimal convert overflow while multiplying 123456780 by scale -539223888: In scope SELECT toDecimal32(toDecimal32('12345678', 1), 3). (DECIMAL_OVERFLOW) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44452) (comment: 00700_decimal_casts_2.sql) (in query: SELECT toDecimal32(toDecimal32('12345678', 1), 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000861f137 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:133: _ZN2DB19convertDecimalsImplINS_15DataTypeDecimalINS_7DecimalIiEEEES4_vQaa17IsDataTypeDecimalIT_E17IsDataTypeDecimalIT0_EEET1_RKNS5_9FieldTypeEjjRNS6_9FieldTypeE @ 0x00000000324e5d01 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:185: _ZN2DB15convertDecimalsINS_15DataTypeDecimalINS_7DecimalIiEEEES4_Qaa17IsDataTypeDecimalIT_E17IsDataTypeDecimalIT0_EEENS6_9FieldTypeERKNS5_9FieldTypeEjj @ 0x00000000324f46da 6. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000091f67d6 7. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091c90df 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:46:57.214363 [ 4841 ] {f70740b4-6b5b-453c-ba64-9172e6c8abe2} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow while multiplying 123456780 by scale -539223888: In scope SELECT toDecimal32(toDecimal32('12345678', 1), 3). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000861f137 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:133: _ZN2DB19convertDecimalsImplINS_15DataTypeDecimalINS_7DecimalIiEEEES4_vQaa17IsDataTypeDecimalIT_E17IsDataTypeDecimalIT0_EEET1_RKNS5_9FieldTypeEjjRNS6_9FieldTypeE @ 0x00000000324e5d01 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:185: _ZN2DB15convertDecimalsINS_15DataTypeDecimalINS_7DecimalIiEEEES4_Qaa17IsDataTypeDecimalIT_E17IsDataTypeDecimalIT0_EEENS6_9FieldTypeERKNS5_9FieldTypeEjj @ 0x00000000324f46da 6. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000091f67d6 7. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091c90df 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:46:57.273150 [ 4841 ] {11e05eda-2517-453d-8711-60ab64955142} executeQuery: Code: 407. DB::Exception: Decimal convert overflow while multiplying 922337203685477581 by scale -9223372036854775806: In scope SELECT toDecimal64(toDecimal64('92233720368547758.1', 1), 2). (DECIMAL_OVERFLOW) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44452) (comment: 00700_decimal_casts_2.sql) (in query: SELECT toDecimal64(toDecimal64('92233720368547758.1', 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000861f137 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:133: _ZN2DB19convertDecimalsImplINS_15DataTypeDecimalINS_7DecimalIlEEEES4_vQaa17IsDataTypeDecimalIT_E17IsDataTypeDecimalIT0_EEET1_RKNS5_9FieldTypeEjjRNS6_9FieldTypeE @ 0x00000000324e9e04 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:185: _ZN2DB15convertDecimalsINS_15DataTypeDecimalINS_7DecimalIlEEEES4_Qaa17IsDataTypeDecimalIT_E17IsDataTypeDecimalIT0_EEENS6_9FieldTypeERKNS5_9FieldTypeEjj @ 0x00000000324f4a9a 6. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000924492f 7. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000921d09f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:46:57.275413 [ 4841 ] {11e05eda-2517-453d-8711-60ab64955142} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow while multiplying 922337203685477581 by scale -9223372036854775806: In scope SELECT toDecimal64(toDecimal64('92233720368547758.1', 1), 2). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000861f137 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:133: _ZN2DB19convertDecimalsImplINS_15DataTypeDecimalINS_7DecimalIlEEEES4_vQaa17IsDataTypeDecimalIT_E17IsDataTypeDecimalIT0_EEET1_RKNS5_9FieldTypeEjjRNS6_9FieldTypeE @ 0x00000000324e9e04 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:185: _ZN2DB15convertDecimalsINS_15DataTypeDecimalINS_7DecimalIlEEEES4_Qaa17IsDataTypeDecimalIT_E17IsDataTypeDecimalIT0_EEENS6_9FieldTypeERKNS5_9FieldTypeEjj @ 0x00000000324f4a9a 6. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000924492f 7. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000921d09f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:46:57.304961 [ 4841 ] {d711d7e5-8b29-4d6c-a161-3d83c613bc66} executeQuery: Code: 407. DB::Exception: Decimal convert overflow while multiplying -922337203685477581 by scale 9223372036854775806: In scope SELECT toDecimal64(toDecimal64('-92233720368547758.1', 1), 2). (DECIMAL_OVERFLOW) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44452) (comment: 00700_decimal_casts_2.sql) (in query: SELECT toDecimal64(toDecimal64('-92233720368547758.1', 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000861f137 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:133: _ZN2DB19convertDecimalsImplINS_15DataTypeDecimalINS_7DecimalIlEEEES4_vQaa17IsDataTypeDecimalIT_E17IsDataTypeDecimalIT0_EEET1_RKNS5_9FieldTypeEjjRNS6_9FieldTypeE @ 0x00000000324e9e04 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:185: _ZN2DB15convertDecimalsINS_15DataTypeDecimalINS_7DecimalIlEEEES4_Qaa17IsDataTypeDecimalIT_E17IsDataTypeDecimalIT0_EEENS6_9FieldTypeERKNS5_9FieldTypeEjj @ 0x00000000324f4a9a 6. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000924492f 7. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000921d09f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:46:57.307226 [ 4841 ] {d711d7e5-8b29-4d6c-a161-3d83c613bc66} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow while multiplying -922337203685477581 by scale 9223372036854775806: In scope SELECT toDecimal64(toDecimal64('-92233720368547758.1', 1), 2). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000861f137 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:133: _ZN2DB19convertDecimalsImplINS_15DataTypeDecimalINS_7DecimalIlEEEES4_vQaa17IsDataTypeDecimalIT_E17IsDataTypeDecimalIT0_EEET1_RKNS5_9FieldTypeEjjRNS6_9FieldTypeE @ 0x00000000324e9e04 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:185: _ZN2DB15convertDecimalsINS_15DataTypeDecimalINS_7DecimalIlEEEES4_Qaa17IsDataTypeDecimalIT_E17IsDataTypeDecimalIT0_EEENS6_9FieldTypeERKNS5_9FieldTypeEjj @ 0x00000000324f4a9a 6. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000924492f 7. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000921d09f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:46:57.499117 [ 3155 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:57.526256 [ 3154 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:57.694229 [ 3133 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:57.784772 [ 3149 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:58.047372 [ 3126 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:58.090939 [ 3894 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:58.157766 [ 3143 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:58.500321 [ 3125 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:58.527527 [ 3114 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:58.695413 [ 3120 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:58.785994 [ 3127 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:59.094096 [ 3101 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:59.158781 [ 3110 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:59.177937 [ 29264 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:46:59.501313 [ 3090 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:59.529036 [ 3100 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:59.779296 [ 3071 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:59.787016 [ 3082 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:59.916669 [ 4841 ] {88faa58d-1fa4-4439-bae3-bfa88f54403f} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('9223372036854775809', 6) AS x, toInt64(x). (DECIMAL_OVERFLOW) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44452) (comment: 00700_decimal_casts_2.sql) (in query: SELECT toDecimal128('9223372036854775809', 6) AS x, toInt64(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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./src/Core/DecimalFunctions.h:346: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, long&) @ 0x00000000324fa31b 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:236: _ZN2DB18convertFromDecimalINS_15DataTypeDecimalINS_7DecimalIN4wide7integerILm128EiEEEEEENS_14DataTypeNumberIlEEQaa17IsDataTypeDecimalIT_E15is_arithmetic_vINT0_9FieldTypeEEEESC_RKNSA_9FieldTypeEj @ 0x0000000032500815 6. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000008aa631b 7. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008a91b5f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:46:59.919144 [ 4841 ] {88faa58d-1fa4-4439-bae3-bfa88f54403f} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('9223372036854775809', 6) AS x, toInt64(x). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./src/Core/DecimalFunctions.h:346: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, long&) @ 0x00000000324fa31b 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:236: _ZN2DB18convertFromDecimalINS_15DataTypeDecimalINS_7DecimalIN4wide7integerILm128EiEEEEEENS_14DataTypeNumberIlEEQaa17IsDataTypeDecimalIT_E15is_arithmetic_vINT0_9FieldTypeEEEESC_RKNSA_9FieldTypeEj @ 0x0000000032500815 6. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000008aa631b 7. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008a91b5f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:46:59.943040 [ 4841 ] {5e728e17-1b22-4294-97e3-f3df9108bc0f} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('9223372036854775809', 6) AS x, toInt64(-x). (DECIMAL_OVERFLOW) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44452) (comment: 00700_decimal_casts_2.sql) (in query: SELECT toDecimal128('9223372036854775809', 6) AS x, toInt64(-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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./src/Core/DecimalFunctions.h:346: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, long&) @ 0x00000000324fa31b 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:236: _ZN2DB18convertFromDecimalINS_15DataTypeDecimalINS_7DecimalIN4wide7integerILm128EiEEEEEENS_14DataTypeNumberIlEEQaa17IsDataTypeDecimalIT_E15is_arithmetic_vINT0_9FieldTypeEEEESC_RKNSA_9FieldTypeEj @ 0x0000000032500815 6. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000008aa631b 7. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008a91b5f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:46:59.944663 [ 4841 ] {5e728e17-1b22-4294-97e3-f3df9108bc0f} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('9223372036854775809', 6) AS x, toInt64(-x). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./src/Core/DecimalFunctions.h:346: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, long&) @ 0x00000000324fa31b 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:236: _ZN2DB18convertFromDecimalINS_15DataTypeDecimalINS_7DecimalIN4wide7integerILm128EiEEEEEENS_14DataTypeNumberIlEEQaa17IsDataTypeDecimalIT_E15is_arithmetic_vINT0_9FieldTypeEEEESC_RKNSA_9FieldTypeEj @ 0x0000000032500815 6. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000008aa631b 7. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008a91b5f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:47:00.096154 [ 3078 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:00.159613 [ 3080 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:00.310133 [ 29264 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:47:00.502260 [ 3070 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:00.529992 [ 3064 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:00.780468 [ 3068 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:00.788269 [ 3055 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:01.097066 [ 3056 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:01.160549 [ 3444 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:01.459320 [ 29264 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:47:01.503105 [ 3391 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:01.530892 [ 3435 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:01.781458 [ 3236 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:01.789212 [ 3223 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:02.020849 [ 4841 ] {af3f127b-9c80-43ce-b895-f2003543dbb1} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('2147483649', 10) AS x, toInt32(x), toInt32(-x). (DECIMAL_OVERFLOW) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44452) (comment: 00700_decimal_casts_2.sql) (in query: SELECT toDecimal128('2147483649', 10) AS x, toInt32(x), toInt32(-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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./src/Core/DecimalFunctions.h:346: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, int&) @ 0x00000000324f6c46 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:236: _ZN2DB18convertFromDecimalINS_15DataTypeDecimalINS_7DecimalIN4wide7integerILm128EiEEEEEENS_14DataTypeNumberIiEEQaa17IsDataTypeDecimalIT_E15is_arithmetic_vINT0_9FieldTypeEEEESC_RKNSA_9FieldTypeEj @ 0x00000000324ffcd5 6. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000008a4fae6 7. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008a3b1ff 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:47:02.023553 [ 4841 ] {af3f127b-9c80-43ce-b895-f2003543dbb1} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('2147483649', 10) AS x, toInt32(x), toInt32(-x). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./src/Core/DecimalFunctions.h:346: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, int&) @ 0x00000000324f6c46 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:236: _ZN2DB18convertFromDecimalINS_15DataTypeDecimalINS_7DecimalIN4wide7integerILm128EiEEEEEENS_14DataTypeNumberIiEEQaa17IsDataTypeDecimalIT_E15is_arithmetic_vINT0_9FieldTypeEEEESC_RKNSA_9FieldTypeEj @ 0x00000000324ffcd5 6. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000008a4fae6 7. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008a3b1ff 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:47:02.098165 [ 3291 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:02.161563 [ 3197 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:02.504365 [ 3135 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:02.505404 [ 29264 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:47:02.532522 [ 3174 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:02.782282 [ 3061 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:02.790333 [ 3562 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:03.099138 [ 3201 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:03.162807 [ 3560 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:03.505332 [ 3552 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:03.533862 [ 3534 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:03.550968 [ 29264 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:47:03.783645 [ 3532 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:03.791473 [ 3529 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:04.100497 [ 3531 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:04.128640 [ 4841 ] {7cab086a-b051-4499-8a92-d31d7b320083} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal64('2147483649', 2) AS x, toInt32(x), toInt32(-x). (DECIMAL_OVERFLOW) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44452) (comment: 00700_decimal_casts_2.sql) (in query: SELECT toDecimal64('2147483649', 2) AS x, toInt32(x), toInt32(-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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./src/Core/DecimalFunctions.h:346: _ZN2DB18convertFromDecimalINS_15DataTypeDecimalINS_7DecimalIlEEEENS_14DataTypeNumberIiEEQaa17IsDataTypeDecimalIT_E15is_arithmetic_vINT0_9FieldTypeEEEES9_RKNS7_9FieldTypeEj @ 0x00000000324ffc03 5. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000008a4da46 6. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008a3b1ff 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 2025.10.23 23:47:04.130158 [ 4841 ] {7cab086a-b051-4499-8a92-d31d7b320083} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal64('2147483649', 2) AS x, toInt32(x), toInt32(-x). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./src/Core/DecimalFunctions.h:346: _ZN2DB18convertFromDecimalINS_15DataTypeDecimalINS_7DecimalIlEEEENS_14DataTypeNumberIiEEQaa17IsDataTypeDecimalIT_E15is_arithmetic_vINT0_9FieldTypeEEEES9_RKNS7_9FieldTypeEj @ 0x00000000324ffc03 5. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000008a4da46 6. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008a3b1ff 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 2025.10.23 23:47:04.164263 [ 3530 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:04.506268 [ 3523 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:04.535370 [ 3516 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:04.610353 [ 29264 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:47:04.785197 [ 3511 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:04.792849 [ 3520 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:05.101369 [ 3505 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:05.165825 [ 3508 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:05.507057 [ 3502 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:05.537266 [ 3498 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:05.774895 [ 29264 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:47:05.786245 [ 3487 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:05.794047 [ 3492 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:06.102154 [ 3483 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:06.166825 [ 3478 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:06.508323 [ 3473 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:06.538620 [ 3480 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:06.787271 [ 3467 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:06.794992 [ 3466 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:06.946477 [ 29264 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:47:07.103032 [ 3470 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:07.168019 [ 3464 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:07.403062 [ 4841 ] {dc5d5a95-4e60-4af5-a928-4d6a44f30e5c} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('-1', 7) AS x, toUInt64(x). (DECIMAL_OVERFLOW) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44452) (comment: 00700_decimal_casts_2.sql) (in query: SELECT toDecimal128('-1', 7) AS x, toUInt64(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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./src/Core/DecimalFunctions.h:346: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, unsigned long&) @ 0x00000000324fae26 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:236: _ZN2DB18convertFromDecimalINS_15DataTypeDecimalINS_7DecimalIN4wide7integerILm128EiEEEEEENS_14DataTypeNumberImEEQaa17IsDataTypeDecimalIT_E15is_arithmetic_vINT0_9FieldTypeEEEESC_RKNSA_9FieldTypeEj @ 0x0000000032501055 6. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088a0b94 7. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000888bc1f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:47:07.405571 [ 4841 ] {dc5d5a95-4e60-4af5-a928-4d6a44f30e5c} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('-1', 7) AS x, toUInt64(x). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./src/Core/DecimalFunctions.h:346: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, unsigned long&) @ 0x00000000324fae26 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:236: _ZN2DB18convertFromDecimalINS_15DataTypeDecimalINS_7DecimalIN4wide7integerILm128EiEEEEEENS_14DataTypeNumberImEEQaa17IsDataTypeDecimalIT_E15is_arithmetic_vINT0_9FieldTypeEEEESC_RKNSA_9FieldTypeEj @ 0x0000000032501055 6. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088a0b94 7. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000888bc1f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:47:07.509293 [ 3446 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:07.540110 [ 3445 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:07.823424 [ 3442 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:07.823508 [ 3456 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:08.000347 [ 29264 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:47:08.168933 [ 3431 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:08.169046 [ 3533 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:08.510325 [ 3419 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:08.541474 [ 3426 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:08.824751 [ 3414 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:08.824813 [ 3417 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:09.133577 [ 29264 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:47:09.170177 [ 3405 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:09.170360 [ 3393 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:09.511384 [ 3397 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:09.542845 [ 3404 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:09.825619 [ 3386 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:09.825896 [ 3389 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:10.010228 [ 4841 ] {67bf4ba4-b9c2-4b89-9309-4962c94ec64a} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('-1', 7) AS x, toUInt32(x). (DECIMAL_OVERFLOW) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44452) (comment: 00700_decimal_casts_2.sql) (in query: SELECT toDecimal128('-1', 7) AS x, toUInt32(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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./src/Core/DecimalFunctions.h:346: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, unsigned int&) @ 0x00000000324f77a7 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:236: _ZN2DB18convertFromDecimalINS_15DataTypeDecimalINS_7DecimalIN4wide7integerILm128EiEEEEEENS_14DataTypeNumberIjEEQaa17IsDataTypeDecimalIT_E15is_arithmetic_vINT0_9FieldTypeEEEESC_RKNSA_9FieldTypeEj @ 0x0000000032500555 6. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088478d4 7. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008832c1f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:47:10.012815 [ 4841 ] {67bf4ba4-b9c2-4b89-9309-4962c94ec64a} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('-1', 7) AS x, toUInt32(x). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./src/Core/DecimalFunctions.h:346: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, unsigned int&) @ 0x00000000324f77a7 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:236: _ZN2DB18convertFromDecimalINS_15DataTypeDecimalINS_7DecimalIN4wide7integerILm128EiEEEEEENS_14DataTypeNumberIjEEQaa17IsDataTypeDecimalIT_E15is_arithmetic_vINT0_9FieldTypeEEEESC_RKNSA_9FieldTypeEj @ 0x0000000032500555 6. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088478d4 7. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008832c1f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:47:10.171095 [ 3383 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:10.171684 [ 3378 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:10.220078 [ 29264 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:47:10.512253 [ 3368 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:10.544062 [ 3370 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:10.826722 [ 3366 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:10.826873 [ 3376 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:11.171901 [ 3358 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:11.172788 [ 3359 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:11.254850 [ 29264 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:47:11.513026 [ 3340 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:11.544864 [ 3352 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:11.828044 [ 3346 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:11.828178 [ 3343 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:11.912540 [ 4841 ] {df2701c8-1d2d-4064-b140-f50ed9171034} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('-1', 7) AS x, toUInt16(x). (DECIMAL_OVERFLOW) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44452) (comment: 00700_decimal_casts_2.sql) (in query: SELECT toDecimal128('-1', 7) AS x, toUInt16(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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./src/Core/DecimalFunctions.h:346: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, unsigned short&) @ 0x00000000324f622d 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:236: _ZN2DB18convertFromDecimalINS_15DataTypeDecimalINS_7DecimalIN4wide7integerILm128EiEEEEEENS_14DataTypeNumberItEEQaa17IsDataTypeDecimalIT_E15is_arithmetic_vINT0_9FieldTypeEEEESC_RKNSA_9FieldTypeEj @ 0x00000000324ff5d4 6. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt16, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt16, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000087ee714 7. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt16, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087d97df 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:47:11.915133 [ 4841 ] {df2701c8-1d2d-4064-b140-f50ed9171034} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('-1', 7) AS x, toUInt16(x). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./src/Core/DecimalFunctions.h:346: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, unsigned short&) @ 0x00000000324f622d 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:236: _ZN2DB18convertFromDecimalINS_15DataTypeDecimalINS_7DecimalIN4wide7integerILm128EiEEEEEENS_14DataTypeNumberItEEQaa17IsDataTypeDecimalIT_E15is_arithmetic_vINT0_9FieldTypeEEEESC_RKNSA_9FieldTypeEj @ 0x00000000324ff5d4 6. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt16, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt16, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000087ee714 7. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt16, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087d97df 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:47:12.172990 [ 3365 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:12.173605 [ 3326 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:12.395382 [ 29264 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:47:12.514056 [ 3330 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:12.546068 [ 3327 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:12.829072 [ 3335 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:12.829121 [ 3324 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:12.940724 [ 3650 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {26a86919-b755-436d-800b-c04857d425d1::202510_1_137_69}: 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 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) @ 0x0000000039c89948 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000003999bfb7 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 @ 0x00000000399942f0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000039d15c04 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&) @ 0x0000000039d20399 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) @ 0x0000000039d1c606 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000396308a4 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x00000000396235dd 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000003963b3e0 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x00000000396504a0 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3c455d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:13.174024 [ 3318 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:13.174513 [ 3317 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:13.491164 [ 3894 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:47:13.514902 [ 3309 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:13.547324 [ 3301 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:13.830023 [ 3282 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:13.830045 [ 3283 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:14.174967 [ 3280 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:14.175866 [ 3281 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:14.508268 [ 4841 ] {1d45e565-df43-4bd4-9437-fb539cede978} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('-1', 7) AS x, toUInt8(x). (DECIMAL_OVERFLOW) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44452) (comment: 00700_decimal_casts_2.sql) (in query: SELECT toDecimal128('-1', 7) AS x, toUInt8(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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./src/Core/DecimalFunctions.h:346: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, char8_t&) @ 0x00000000324f8ced 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:236: _ZN2DB18convertFromDecimalINS_15DataTypeDecimalINS_7DecimalIN4wide7integerILm128EiEEEEEENS_14DataTypeNumberIDuEEQaa17IsDataTypeDecimalIT_E15is_arithmetic_vINT0_9FieldTypeEEEESC_RKNSA_9FieldTypeEj @ 0x00000000324fe412 6. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt8, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt8, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000878b8d6 7. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt8, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000876f0ff 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:47:14.509736 [ 4841 ] {1d45e565-df43-4bd4-9437-fb539cede978} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('-1', 7) AS x, toUInt8(x). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./src/Core/DecimalFunctions.h:346: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, char8_t&) @ 0x00000000324f8ced 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:236: _ZN2DB18convertFromDecimalINS_15DataTypeDecimalINS_7DecimalIN4wide7integerILm128EiEEEEEENS_14DataTypeNumberIDuEEQaa17IsDataTypeDecimalIT_E15is_arithmetic_vINT0_9FieldTypeEEEESC_RKNSA_9FieldTypeEj @ 0x00000000324fe412 6. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt8, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt8, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000878b8d6 7. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt8, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000876f0ff 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:47:14.515633 [ 3267 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:14.548747 [ 3268 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:14.557987 [ 3894 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:47:14.830917 [ 3252 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:14.830976 [ 3255 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:15.176028 [ 3248 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:15.176723 [ 3243 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:15.516558 [ 3244 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:15.549674 [ 3242 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:15.607036 [ 3894 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:47:15.905009 [ 3226 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:15.905038 [ 3231 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:16.177234 [ 3228 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:16.177809 [ 3232 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:16.517600 [ 3215 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:16.550852 [ 3212 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:16.659668 [ 3894 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:47:16.906313 [ 3200 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:16.906517 [ 3198 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:17.178372 [ 3199 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:17.178897 [ 3194 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:17.518677 [ 3191 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:17.552565 [ 3184 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:17.669950 [ 4841 ] {71d655bf-d62c-4450-9143-861ec6a03773} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal64('-1', 5) AS x, toUInt64(x). (DECIMAL_OVERFLOW) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44452) (comment: 00700_decimal_casts_2.sql) (in query: SELECT toDecimal64('-1', 5) AS x, toUInt64(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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./src/Core/DecimalFunctions.h:326: _ZN2DB18convertFromDecimalINS_15DataTypeDecimalINS_7DecimalIlEEEENS_14DataTypeNumberImEEQaa17IsDataTypeDecimalIT_E15is_arithmetic_vINT0_9FieldTypeEEEES9_RKNS7_9FieldTypeEj @ 0x0000000032500f7a 5. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000889ec41 6. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000888bc1f 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 2025.10.23 23:47:17.671758 [ 4841 ] {71d655bf-d62c-4450-9143-861ec6a03773} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal64('-1', 5) AS x, toUInt64(x). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./src/Core/DecimalFunctions.h:326: _ZN2DB18convertFromDecimalINS_15DataTypeDecimalINS_7DecimalIlEEEENS_14DataTypeNumberImEEQaa17IsDataTypeDecimalIT_E15is_arithmetic_vINT0_9FieldTypeEEEES9_RKNS7_9FieldTypeEj @ 0x0000000032500f7a 5. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000889ec41 6. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000888bc1f 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 2025.10.23 23:47:17.728563 [ 3894 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:47:17.907342 [ 3187 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:17.907585 [ 3182 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:18.179448 [ 3176 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:18.180103 [ 3178 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:18.519681 [ 3156 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:18.553750 [ 3160 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:18.838670 [ 3894 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:47:18.908469 [ 3155 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:18.908972 [ 3154 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:19.181331 [ 3133 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:19.188911 [ 3134 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:19.520835 [ 3137 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:19.554770 [ 3149 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:19.909600 [ 3121 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:19.910105 [ 3119 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:19.957620 [ 4841 ] {870c4741-38d3-4934-988e-c20d12166ef2} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal64('-1', 5) AS x, toUInt32(x). (DECIMAL_OVERFLOW) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44452) (comment: 00700_decimal_casts_2.sql) (in query: SELECT toDecimal64('-1', 5) AS x, toUInt32(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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./src/Core/DecimalFunctions.h:346: _ZN2DB18convertFromDecimalINS_15DataTypeDecimalINS_7DecimalIlEEEENS_14DataTypeNumberIjEEQaa17IsDataTypeDecimalIT_E15is_arithmetic_vINT0_9FieldTypeEEEES9_RKNS7_9FieldTypeEj @ 0x0000000032500479 5. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000008845b34 6. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008832c1f 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 2025.10.23 23:47:19.959302 [ 4841 ] {870c4741-38d3-4934-988e-c20d12166ef2} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal64('-1', 5) AS x, toUInt32(x). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./src/Core/DecimalFunctions.h:346: _ZN2DB18convertFromDecimalINS_15DataTypeDecimalINS_7DecimalIlEEEENS_14DataTypeNumberIjEEQaa17IsDataTypeDecimalIT_E15is_arithmetic_vINT0_9FieldTypeEEEES9_RKNS7_9FieldTypeEj @ 0x0000000032500479 5. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000008845b34 6. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008832c1f 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 2025.10.23 23:47:20.056237 [ 3894 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:47:20.182756 [ 3129 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:20.189762 [ 3131 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:20.521666 [ 3114 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:20.556318 [ 3109 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:20.910446 [ 3112 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:20.910965 [ 3112 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:21.155312 [ 3894 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:47:21.183839 [ 3159 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:21.190495 [ 3101 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:21.522765 [ 3087 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:21.557881 [ 3088 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:21.785375 [ 4841 ] {9462bc46-59f9-4b0b-b3f9-8abd7eced016} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal64('-1', 5) AS x, toUInt16(x). (DECIMAL_OVERFLOW) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44452) (comment: 00700_decimal_casts_2.sql) (in query: SELECT toDecimal64('-1', 5) AS x, toUInt16(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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./src/Core/DecimalFunctions.h:346: _ZN2DB18convertFromDecimalINS_15DataTypeDecimalINS_7DecimalIlEEEENS_14DataTypeNumberItEEQaa17IsDataTypeDecimalIT_E15is_arithmetic_vINT0_9FieldTypeEEEES9_RKNS7_9FieldTypeEj @ 0x00000000324ff503 5. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt16, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt16, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000087ec854 6. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt16, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087d97df 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 2025.10.23 23:47:21.787632 [ 4841 ] {9462bc46-59f9-4b0b-b3f9-8abd7eced016} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal64('-1', 5) AS x, toUInt16(x). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./src/Core/DecimalFunctions.h:346: _ZN2DB18convertFromDecimalINS_15DataTypeDecimalINS_7DecimalIlEEEENS_14DataTypeNumberItEEQaa17IsDataTypeDecimalIT_E15is_arithmetic_vINT0_9FieldTypeEEEES9_RKNS7_9FieldTypeEj @ 0x00000000324ff503 5. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt16, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt16, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000087ec854 6. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt16, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087d97df 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 2025.10.23 23:47:21.911232 [ 3092 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:21.912096 [ 3071 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:22.184787 [ 3105 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:22.191174 [ 3077 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:22.315290 [ 3894 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:47:22.524130 [ 3073 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:22.559298 [ 3064 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:22.985835 [ 3056 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:22.985870 [ 3067 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:23.186157 [ 3391 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:23.192081 [ 3435 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:23.525264 [ 3329 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:23.561036 [ 3265 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:23.987115 [ 3203 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:23.987182 [ 3168 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:24.187899 [ 3098 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:24.193101 [ 3061 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:24.310307 [ 4841 ] {d0e37aa2-7ec5-4072-9955-1c3633fe8aaa} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal64('-1', 5) AS x, toUInt8(x). (DECIMAL_OVERFLOW) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44452) (comment: 00700_decimal_casts_2.sql) (in query: SELECT toDecimal64('-1', 5) AS x, toUInt8(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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./src/Core/DecimalFunctions.h:346: _ZN2DB18convertFromDecimalINS_15DataTypeDecimalINS_7DecimalIlEEEENS_14DataTypeNumberIDuEEQaa17IsDataTypeDecimalIT_E15is_arithmetic_vINT0_9FieldTypeEEEES9_RKNS7_9FieldTypeEj @ 0x00000000324fe343 5. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt8, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt8, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000878a8d6 6. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt8, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000876f0ff 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 2025.10.23 23:47:24.312834 [ 4841 ] {d0e37aa2-7ec5-4072-9955-1c3633fe8aaa} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal64('-1', 5) AS x, toUInt8(x). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./src/Core/DecimalFunctions.h:346: _ZN2DB18convertFromDecimalINS_15DataTypeDecimalINS_7DecimalIlEEEENS_14DataTypeNumberIDuEEQaa17IsDataTypeDecimalIT_E15is_arithmetic_vINT0_9FieldTypeEEEES9_RKNS7_9FieldTypeEj @ 0x00000000324fe343 5. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt8, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt8, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000878a8d6 6. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt8, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000876f0ff 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 2025.10.23 23:47:24.526619 [ 3201 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:24.562224 [ 3560 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:24.988503 [ 3565 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:24.988600 [ 3552 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:25.187031 [ 29264 ] {1b4df0ba-3da0-4554-976d-baeedbc2a293} executeQuery: Code: 107. DB::Exception: File /var/lib/clickhouse/store/95c/95cfd7ae-489a-47b8-a2b2-95e6a3333ed1//data.TSV doesn't exist. (FILE_DOESNT_EXIST) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38482) (comment: 00832_storage_file_lock.sql) (in query: SELECT * 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 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) @ 0x000000003833de02 5. ./src/Processors/QueryPlan/QueryPlan.h:53: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000034d80c82 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1777: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d67094 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0b8de 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cfd8b2 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034cf6172 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5bf1 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:47:25.189166 [ 29264 ] {1b4df0ba-3da0-4554-976d-baeedbc2a293} TCPHandler: Code: 107. DB::Exception: File /var/lib/clickhouse/store/95c/95cfd7ae-489a-47b8-a2b2-95e6a3333ed1//data.TSV 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 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) @ 0x000000003833de02 5. ./src/Processors/QueryPlan/QueryPlan.h:53: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000034d80c82 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1777: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d67094 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0b8de 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cfd8b2 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034cf6172 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5bf1 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:47:25.189288 [ 3553 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:25.194197 [ 3535 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:25.260744 [ 3894 ] {af7e39bf-c4de-4cc4-8250-19b6f6275bd7} executeQuery: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column '__table1.c' of type 'UInt64'. (INVALID_JOIN_ON_EXPRESSION) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38470) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (in query: SELECT t1.*, t2.* from t1 LEFT JOIN t2 ON t1.key = t2.key and t1.c ORDER BY (t1.key, t1.attr, t2.key, t2.attr);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa0996d 4. ./build_docker/./src/Interpreters/JoinUtils.cpp:426: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x0000000034ec8b9f 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:431: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x0000000034ec83ed 6. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:0: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000035c4cb58 7. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:0: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x000000003b83f981 8. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:104: DB::JoinStep::updateOutputStream() @ 0x000000003be75c7a 9. ./src/Processors/QueryPlan/IQueryPlanStep.h:125: DB::IQueryPlanStep::updateInputStreams(std::vector>) @ 0x000000003be79984 10. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:0: DB::JoinStep::JoinStep(DB::DataStream const&, DB::DataStream const&, std::shared_ptr, unsigned long, unsigned long, bool) @ 0x000000003be726c2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h: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&) @ 0x0000000034d97139 12. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d6a797 13. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0b8de 14. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cfd8b2 15. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034cf6172 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5bf1 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:47:25.263677 [ 3894 ] {af7e39bf-c4de-4cc4-8250-19b6f6275bd7} TCPHandler: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column '__table1.c' of type 'UInt64'. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa0996d 4. ./build_docker/./src/Interpreters/JoinUtils.cpp:426: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x0000000034ec8b9f 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:431: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x0000000034ec83ed 6. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:0: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000035c4cb58 7. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:0: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x000000003b83f981 8. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:104: DB::JoinStep::updateOutputStream() @ 0x000000003be75c7a 9. ./src/Processors/QueryPlan/IQueryPlanStep.h:125: DB::IQueryPlanStep::updateInputStreams(std::vector>) @ 0x000000003be79984 10. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:0: DB::JoinStep::JoinStep(DB::DataStream const&, DB::DataStream const&, std::shared_ptr, unsigned long, unsigned long, bool) @ 0x000000003be726c2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h: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&) @ 0x0000000034d97139 12. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d6a797 13. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0b8de 14. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cfd8b2 15. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034cf6172 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5bf1 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:47:25.528119 [ 3566 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:25.563592 [ 3558 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:25.989673 [ 3546 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:25.989734 [ 3519 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:26.190373 [ 3521 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:26.195165 [ 3547 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:26.529002 [ 3524 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:26.564611 [ 3506 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:26.816134 [ 3894 ] {d4b2bb83-d9d9-43ed-87d5-99708cef69d3} executeQuery: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column '__table1.c' of type 'UInt64'. (INVALID_JOIN_ON_EXPRESSION) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38470) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (in query: SELECT t1.*, t2.* from t1 INNER JOIN t2 ON t1.key = t2.key and t1.c ORDER BY (t1.key, t1.attr, t2.key, t2.attr);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa0996d 4. ./build_docker/./src/Interpreters/JoinUtils.cpp:426: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x0000000034ec8b9f 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:431: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x0000000034ec83ed 6. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:0: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000035c4cb58 7. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:0: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x000000003b83f981 8. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:104: DB::JoinStep::updateOutputStream() @ 0x000000003be75c7a 9. ./src/Processors/QueryPlan/IQueryPlanStep.h:125: DB::IQueryPlanStep::updateInputStreams(std::vector>) @ 0x000000003be79984 10. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:0: DB::JoinStep::JoinStep(DB::DataStream const&, DB::DataStream const&, std::shared_ptr, unsigned long, unsigned long, bool) @ 0x000000003be726c2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h: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&) @ 0x0000000034d97139 12. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d6a797 13. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0b8de 14. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cfd8b2 15. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034cf6172 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5bf1 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:47:26.817914 [ 3894 ] {d4b2bb83-d9d9-43ed-87d5-99708cef69d3} TCPHandler: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column '__table1.c' of type 'UInt64'. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa0996d 4. ./build_docker/./src/Interpreters/JoinUtils.cpp:426: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x0000000034ec8b9f 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:431: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x0000000034ec83ed 6. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:0: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000035c4cb58 7. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:0: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x000000003b83f981 8. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:104: DB::JoinStep::updateOutputStream() @ 0x000000003be75c7a 9. ./src/Processors/QueryPlan/IQueryPlanStep.h:125: DB::IQueryPlanStep::updateInputStreams(std::vector>) @ 0x000000003be79984 10. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:0: DB::JoinStep::JoinStep(DB::DataStream const&, DB::DataStream const&, std::shared_ptr, unsigned long, unsigned long, bool) @ 0x000000003be726c2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h: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&) @ 0x0000000034d97139 12. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d6a797 13. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0b8de 14. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cfd8b2 15. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034cf6172 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5bf1 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:47:26.990680 [ 3513 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:26.990819 [ 3501 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:27.191961 [ 3499 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:27.196477 [ 3500 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:27.385972 [ 3894 ] {f3774177-e883-496f-a2b8-5942f20adfce} 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.10542.altinitytest (altinity build)) (from [::1]:38470) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (in query: SELECT t1.*, t2.* FROM t1 RIGHT JOIN t2 ON (t1.a < t2.a OR lower(t1.attr) == lower(t2.attr)) AND t1.key = t2.key ORDER BY (t1.key, t1.attr, t2.key, t2.attr);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000039d07892 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&) @ 0x0000000039d09d4a 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:63: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x00000000326402a2 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000032640cad 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000039d01224 14. ./contrib/llvm-project/libcxx/include/vector:547: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000039d00b49 15. ./contrib/llvm-project/libcxx/include/__tree:1088: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) @ 0x00000000399bb1c8 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 @ 0x00000000399b0254 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039d45fb0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003bfd663a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c083c53 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003bfe2b53 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d3c440 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf89b85 23. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 24. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 28. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 31. ? @ 0x00007f100c857ac3 2025.10.23 23:47:27.391034 [ 3894 ] {f3774177-e883-496f-a2b8-5942f20adfce} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000039d07892 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&) @ 0x0000000039d09d4a 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:63: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x00000000326402a2 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000032640cad 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000039d01224 14. ./contrib/llvm-project/libcxx/include/vector:547: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000039d00b49 15. ./contrib/llvm-project/libcxx/include/__tree:1088: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) @ 0x00000000399bb1c8 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 @ 0x00000000399b0254 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039d45fb0 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003bfd663a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c083c53 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003bfe2b53 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d3c440 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf89b85 23. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 24. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 28. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 31. ? @ 0x00007f100c857ac3 2025.10.23 23:47:27.529835 [ 3495 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:27.565845 [ 3502 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:27.922023 [ 29264 ] {f9053de7-f43e-4e8c-9129-fc774252938d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=748). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:50426) (comment: 01064_pm_all_join_const_and_nullable.sql) (in query: SELECT 'first 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:47:27.925340 [ 29264 ] {f9053de7-f43e-4e8c-9129-fc774252938d} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=748). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:47:27.991544 [ 3481 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:27.992147 [ 3486 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:28.137984 [ 4841 ] {f192bc8d-e94e-40c9-8bbb-0cd40869116c} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal32('-1', 3) AS x, toUInt64(x). (DECIMAL_OVERFLOW) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44452) (comment: 00700_decimal_casts_2.sql) (in query: SELECT toDecimal32('-1', 3) AS x, toUInt64(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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./src/Core/DecimalFunctions.h:326: _ZN2DB18convertFromDecimalINS_15DataTypeDecimalINS_7DecimalIiEEEENS_14DataTypeNumberImEEQaa17IsDataTypeDecimalIT_E15is_arithmetic_vINT0_9FieldTypeEEEES9_RKNS7_9FieldTypeEj @ 0x0000000032500d05 5. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000889f8a4 6. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000888bc1f 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 2025.10.23 23:47:28.140468 [ 4841 ] {f192bc8d-e94e-40c9-8bbb-0cd40869116c} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal32('-1', 3) AS x, toUInt64(x). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./src/Core/DecimalFunctions.h:326: _ZN2DB18convertFromDecimalINS_15DataTypeDecimalINS_7DecimalIiEEEENS_14DataTypeNumberImEEQaa17IsDataTypeDecimalIT_E15is_arithmetic_vINT0_9FieldTypeEEEES9_RKNS7_9FieldTypeEj @ 0x0000000032500d05 5. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000889f8a4 6. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000888bc1f 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 2025.10.23 23:47:28.193075 [ 3475 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:28.197347 [ 3512 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:28.530829 [ 3472 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:28.567204 [ 3468 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:28.992694 [ 3453 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:28.993431 [ 3448 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:29.194256 [ 3434 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:29.198122 [ 3440 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:29.532186 [ 3438 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:29.569073 [ 3432 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:29.981854 [ 3415 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTablesParallel(std::vector, std::allocator>>) @ 0x00000000339c8298 8. ./contrib/llvm-project/libcxx/include/vector:438: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000339c92ee 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000339ec17f 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:29.993773 [ 3414 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:29.994796 [ 3417 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:30.195520 [ 3405 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:30.198892 [ 3393 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:30.533213 [ 3404 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:30.570296 [ 3384 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:30.994860 [ 3398 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:30.996069 [ 3377 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:31.208809 [ 3383 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:31.282105 [ 3367 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:31.373667 [ 4841 ] {779ef1ba-2b67-4e95-a4c6-556fea4a3f0c} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal32('-1', 3) AS x, toUInt32(x). (DECIMAL_OVERFLOW) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44452) (comment: 00700_decimal_casts_2.sql) (in query: SELECT toDecimal32('-1', 3) AS x, toUInt32(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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./src/Core/DecimalFunctions.h:326: _ZN2DB18convertFromDecimalINS_15DataTypeDecimalINS_7DecimalIiEEEENS_14DataTypeNumberIjEEQaa17IsDataTypeDecimalIT_E15is_arithmetic_vINT0_9FieldTypeEEEES9_RKNS7_9FieldTypeEj @ 0x00000000325001e5 5. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000008846741 6. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008832c1f 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 2025.10.23 23:47:31.376118 [ 4841 ] {779ef1ba-2b67-4e95-a4c6-556fea4a3f0c} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal32('-1', 3) AS x, toUInt32(x). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./src/Core/DecimalFunctions.h:326: _ZN2DB18convertFromDecimalINS_15DataTypeDecimalINS_7DecimalIiEEEENS_14DataTypeNumberIjEEQaa17IsDataTypeDecimalIT_E15is_arithmetic_vINT0_9FieldTypeEEEES9_RKNS7_9FieldTypeEj @ 0x00000000325001e5 5. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000008846741 6. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008832c1f 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 2025.10.23 23:47:31.534286 [ 3379 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:31.571362 [ 3366 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:31.962983 [ 29264 ] {a9189af3-01d9-4a72-b25f-f0b1dee6183b} executeQuery: Code: 57. DB::Exception: Table test_15.t already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:50482) (comment: 02867_nullable_primary_key_final.sql) (in query: CREATE TABLE t (`d` Nullable(Date), `f1` Nullable(String), `f2` Nullable(String), `c` Nullable(Int64)) ENGINE = ReplacingMergeTree ORDER BY (f1, f2, d) SETTINGS allow_nullable_key = 1, index_granularity = 40657, min_bytes_for_wide_part = 228775568, ratio_of_defaults_for_sparse_serialization = 0.8870179653167725, replace_long_file_name_to_hash = true, max_file_name_length = 32, min_bytes_for_full_part_storage = 57121004, compact_parts_max_bytes_to_buffer = 401397091, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 7242899, merge_max_block_size = 22870, 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 = 100, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 1665236, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 56712, primary_key_compress_block_size = 84345), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:47:31.965882 [ 29264 ] {a9189af3-01d9-4a72-b25f-f0b1dee6183b} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:47:31.996127 [ 3351 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:31.997128 [ 3361 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:32.209753 [ 3354 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:32.283578 [ 3340 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:32.499198 [ 3894 ] {e911f87b-dfa5-4d78-bd37-24bb3ae66dd0} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:50466) (comment: 03013_group_by_use_nulls_with_materialize_and_analyzer.sql) (in query: SELECT ignore(3) from numbers(10) GROUP BY GROUPING SETS (('str'), (ignore(3))) 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:47:32.535477 [ 3343 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:32.572489 [ 3337 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:32.616016 [ 3894 ] {e911f87b-dfa5-4d78-bd37-24bb3ae66dd0} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:47:32.996975 [ 3325 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:32.998058 [ 3355 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:33.210710 [ 3327 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:33.284851 [ 3331 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:33.536752 [ 3348 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:33.573978 [ 3315 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:33.645595 [ 4841 ] {95c0bd2a-f7fc-4f8b-be8f-b669246bddb5} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal32('-1', 3) AS x, toUInt16(x). (DECIMAL_OVERFLOW) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44452) (comment: 00700_decimal_casts_2.sql) (in query: SELECT toDecimal32('-1', 3) AS x, toUInt16(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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./src/Core/DecimalFunctions.h:346: _ZN2DB18convertFromDecimalINS_15DataTypeDecimalINS_7DecimalIiEEEENS_14DataTypeNumberItEEQaa17IsDataTypeDecimalIT_E15is_arithmetic_vINT0_9FieldTypeEEEES9_RKNS7_9FieldTypeEj @ 0x00000000324ff268 5. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt16, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt16, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000087ed474 6. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt16, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087d97df 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 2025.10.23 23:47:33.647228 [ 4841 ] {95c0bd2a-f7fc-4f8b-be8f-b669246bddb5} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal32('-1', 3) AS x, toUInt16(x). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./src/Core/DecimalFunctions.h:346: _ZN2DB18convertFromDecimalINS_15DataTypeDecimalINS_7DecimalIiEEEENS_14DataTypeNumberItEEQaa17IsDataTypeDecimalIT_E15is_arithmetic_vINT0_9FieldTypeEEEES9_RKNS7_9FieldTypeEj @ 0x00000000324ff268 5. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt16, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt16, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000087ed474 6. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt16, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087d97df 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 2025.10.23 23:47:33.997962 [ 3318 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:33.999006 [ 3317 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:34.212052 [ 3321 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:34.286103 [ 3305 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:34.537801 [ 3303 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:34.575489 [ 3300 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:34.999041 [ 3312 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:35.000350 [ 3288 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:35.212966 [ 3289 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:35.287549 [ 3286 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:35.539097 [ 3279 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:35.577198 [ 3280 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:36.000420 [ 3268 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:36.001420 [ 3270 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:36.125934 [ 4841 ] {26554033-8d3c-47d3-ad91-0146d60a4ff3} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal32('-1', 3) AS x, toUInt8(x). (DECIMAL_OVERFLOW) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44452) (comment: 00700_decimal_casts_2.sql) (in query: SELECT toDecimal32('-1', 3) AS x, toUInt8(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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./src/Core/DecimalFunctions.h:346: _ZN2DB18convertFromDecimalINS_15DataTypeDecimalINS_7DecimalIiEEEENS_14DataTypeNumberIDuEEQaa17IsDataTypeDecimalIT_E15is_arithmetic_vINT0_9FieldTypeEEEES9_RKNS7_9FieldTypeEj @ 0x00000000324fe0a7 5. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt8, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt8, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000878ad44 6. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt8, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000876f0ff 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 2025.10.23 23:47:36.128315 [ 4841 ] {26554033-8d3c-47d3-ad91-0146d60a4ff3} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal32('-1', 3) AS x, toUInt8(x). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./src/Core/DecimalFunctions.h:346: _ZN2DB18convertFromDecimalINS_15DataTypeDecimalINS_7DecimalIiEEEENS_14DataTypeNumberIDuEEQaa17IsDataTypeDecimalIT_E15is_arithmetic_vINT0_9FieldTypeEEEES9_RKNS7_9FieldTypeEj @ 0x00000000324fe0a7 5. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt8, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt8, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000878ad44 6. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt8, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000876f0ff 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 2025.10.23 23:47:36.189153 [ 29264 ] {ceec8cc4-2223-4a7b-acc7-36a5159a7eb9} executeQuery: Code: 636. DB::Exception: The table structure cannot be extracted from a Parquet format file, because there are no files with provided path in S3ObjectStorage or all files are empty. You can specify table structure manually: The table structure cannot be extracted from a Parquet format file. You can specify the structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:50498) (comment: 02481_s3_throw_if_mismatch_files.sql) (in query: select a, b from s3(s3_conn, filename='test_02481_mismatch_filesxxx*', format=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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&&) @ 0x000000000df4df8d 4. ./build_docker/./src/Storages/ObjectStorage/ReadBufferIterator.cpp:196: DB::ReadBufferIterator::next() @ 0x0000000030a0b8a9 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003adb3fda 6. ./src/Storages/ColumnsDescription.h:113: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003adc5f55 7. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:0: DB::StorageObjectStorage::resolveSchemaFromData(std::shared_ptr const&, std::shared_ptr const&, std::optional const&, String&, std::shared_ptr const&) @ 0x00000000309f2747 8. ./build_docker/./src/Storages/ObjectStorage/Utils.cpp:0: DB::resolveSchemaAndFormat(DB::ColumnsDescription&, String&, std::shared_ptr, std::shared_ptr const&, std::optional, String&, std::shared_ptr const&) @ 0x0000000030a8098e 9. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:86: DB::StorageObjectStorage::StorageObjectStorage(std::shared_ptr, std::shared_ptr, std::shared_ptr, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::optional, bool, std::shared_ptr) @ 0x00000000309e8c1d 10. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageObjectStorage* std::construct_at[abi:v15007]&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, bool, std::nullptr_t, DB::StorageObjectStorage*>(DB::StorageObjectStorage*, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, bool&&, std::nullptr_t&&) @ 0x000000002ff29719 11. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, bool, std::nullptr_t, void>(std::allocator const&, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, bool&&, std::nullptr_t&&) @ 0x000000002ff28ffd 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionObjectStorage::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002fef4266 13. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f70b3 14. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000003374cff2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4838: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003345fff3 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334edd21 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436960 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 2025.10.23 23:47:36.191815 [ 29264 ] {ceec8cc4-2223-4a7b-acc7-36a5159a7eb9} TCPHandler: Code: 636. DB::Exception: The table structure cannot be extracted from a Parquet format file, because there are no files with provided path in S3ObjectStorage or all files are empty. You can specify table structure manually: The table structure cannot be extracted from a Parquet format file. 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&&) @ 0x000000000df4df8d 4. ./build_docker/./src/Storages/ObjectStorage/ReadBufferIterator.cpp:196: DB::ReadBufferIterator::next() @ 0x0000000030a0b8a9 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003adb3fda 6. ./src/Storages/ColumnsDescription.h:113: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003adc5f55 7. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:0: DB::StorageObjectStorage::resolveSchemaFromData(std::shared_ptr const&, std::shared_ptr const&, std::optional const&, String&, std::shared_ptr const&) @ 0x00000000309f2747 8. ./build_docker/./src/Storages/ObjectStorage/Utils.cpp:0: DB::resolveSchemaAndFormat(DB::ColumnsDescription&, String&, std::shared_ptr, std::shared_ptr const&, std::optional, String&, std::shared_ptr const&) @ 0x0000000030a8098e 9. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:86: DB::StorageObjectStorage::StorageObjectStorage(std::shared_ptr, std::shared_ptr, std::shared_ptr, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::optional, bool, std::shared_ptr) @ 0x00000000309e8c1d 10. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageObjectStorage* std::construct_at[abi:v15007]&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, bool, std::nullptr_t, DB::StorageObjectStorage*>(DB::StorageObjectStorage*, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, bool&&, std::nullptr_t&&) @ 0x000000002ff29719 11. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, bool, std::nullptr_t, void>(std::allocator const&, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, bool&&, std::nullptr_t&&) @ 0x000000002ff28ffd 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionObjectStorage::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002fef4266 13. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f70b3 14. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000003374cff2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4838: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003345fff3 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334edd21 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436960 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 2025.10.23 23:47:36.214056 [ 3257 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:36.229217 [ 4841 ] {bc364998-34e5-4451-8d8b-b6119bb6e220} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('18446744073709551616', 0) AS x, toUInt64(x). (DECIMAL_OVERFLOW) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44452) (comment: 00700_decimal_casts_2.sql) (in query: SELECT toDecimal128('18446744073709551616', 0) AS x, toUInt64(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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./src/Core/DecimalFunctions.h:346: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, unsigned long&) @ 0x00000000324fae26 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:236: _ZN2DB18convertFromDecimalINS_15DataTypeDecimalINS_7DecimalIN4wide7integerILm128EiEEEEEENS_14DataTypeNumberImEEQaa17IsDataTypeDecimalIT_E15is_arithmetic_vINT0_9FieldTypeEEEESC_RKNSA_9FieldTypeEj @ 0x0000000032501055 6. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088a0b94 7. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000888bc1f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:47:36.231601 [ 4841 ] {bc364998-34e5-4451-8d8b-b6119bb6e220} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('18446744073709551616', 0) AS x, toUInt64(x). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./src/Core/DecimalFunctions.h:346: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, unsigned long&) @ 0x00000000324fae26 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:236: _ZN2DB18convertFromDecimalINS_15DataTypeDecimalINS_7DecimalIN4wide7integerILm128EiEEEEEENS_14DataTypeNumberImEEQaa17IsDataTypeDecimalIT_E15is_arithmetic_vINT0_9FieldTypeEEEESC_RKNSA_9FieldTypeEj @ 0x0000000032501055 6. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088a0b94 7. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000888bc1f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:47:36.288869 [ 3260 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:36.434297 [ 4841 ] {f65f9537-f1c7-47aa-8517-557a256f73a9} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('18446744073709551616', 8) AS x, toUInt64(x). (DECIMAL_OVERFLOW) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44452) (comment: 00700_decimal_casts_2.sql) (in query: SELECT toDecimal128('18446744073709551616', 8) AS x, toUInt64(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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./src/Core/DecimalFunctions.h:346: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, unsigned long&) @ 0x00000000324fae26 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:236: _ZN2DB18convertFromDecimalINS_15DataTypeDecimalINS_7DecimalIN4wide7integerILm128EiEEEEEENS_14DataTypeNumberImEEQaa17IsDataTypeDecimalIT_E15is_arithmetic_vINT0_9FieldTypeEEEESC_RKNSA_9FieldTypeEj @ 0x0000000032501055 6. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088a0b94 7. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000888bc1f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:47:36.436595 [ 4841 ] {f65f9537-f1c7-47aa-8517-557a256f73a9} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('18446744073709551616', 8) AS x, toUInt64(x). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./src/Core/DecimalFunctions.h:346: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, unsigned long&) @ 0x00000000324fae26 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:236: _ZN2DB18convertFromDecimalINS_15DataTypeDecimalINS_7DecimalIN4wide7integerILm128EiEEEEEENS_14DataTypeNumberImEEQaa17IsDataTypeDecimalIT_E15is_arithmetic_vINT0_9FieldTypeEEEESC_RKNSA_9FieldTypeEj @ 0x0000000032501055 6. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088a0b94 7. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000888bc1f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:47:36.523975 [ 4841 ] {ed5d20b9-420f-4042-89d5-fb316f1d9e49} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('4294967296', 0) AS x, toUInt32(x). (DECIMAL_OVERFLOW) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44452) (comment: 00700_decimal_casts_2.sql) (in query: SELECT toDecimal128('4294967296', 0) AS x, toUInt32(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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./src/Core/DecimalFunctions.h:346: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, unsigned int&) @ 0x00000000324f77a7 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:236: _ZN2DB18convertFromDecimalINS_15DataTypeDecimalINS_7DecimalIN4wide7integerILm128EiEEEEEENS_14DataTypeNumberIjEEQaa17IsDataTypeDecimalIT_E15is_arithmetic_vINT0_9FieldTypeEEEESC_RKNSA_9FieldTypeEj @ 0x0000000032500555 6. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088478d4 7. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008832c1f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:47:36.526008 [ 4841 ] {ed5d20b9-420f-4042-89d5-fb316f1d9e49} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('4294967296', 0) AS x, toUInt32(x). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./src/Core/DecimalFunctions.h:346: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, unsigned int&) @ 0x00000000324f77a7 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:236: _ZN2DB18convertFromDecimalINS_15DataTypeDecimalINS_7DecimalIN4wide7integerILm128EiEEEEEENS_14DataTypeNumberIjEEQaa17IsDataTypeDecimalIT_E15is_arithmetic_vINT0_9FieldTypeEEEESC_RKNSA_9FieldTypeEj @ 0x0000000032500555 6. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088478d4 7. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008832c1f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:47:36.540367 [ 3251 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:36.578681 [ 3243 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:36.619126 [ 4841 ] {8e115649-2842-435b-a4e1-0286f8341a80} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('4294967296', 10) AS x, toUInt32(x). (DECIMAL_OVERFLOW) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44452) (comment: 00700_decimal_casts_2.sql) (in query: SELECT toDecimal128('4294967296', 10) AS x, toUInt32(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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./src/Core/DecimalFunctions.h:346: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, unsigned int&) @ 0x00000000324f77a7 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:236: _ZN2DB18convertFromDecimalINS_15DataTypeDecimalINS_7DecimalIN4wide7integerILm128EiEEEEEENS_14DataTypeNumberIjEEQaa17IsDataTypeDecimalIT_E15is_arithmetic_vINT0_9FieldTypeEEEESC_RKNSA_9FieldTypeEj @ 0x0000000032500555 6. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088478d4 7. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008832c1f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:47:36.621340 [ 4841 ] {8e115649-2842-435b-a4e1-0286f8341a80} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('4294967296', 10) AS x, toUInt32(x). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./src/Core/DecimalFunctions.h:346: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, unsigned int&) @ 0x00000000324f77a7 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:236: _ZN2DB18convertFromDecimalINS_15DataTypeDecimalINS_7DecimalIN4wide7integerILm128EiEEEEEENS_14DataTypeNumberIjEEQaa17IsDataTypeDecimalIT_E15is_arithmetic_vINT0_9FieldTypeEEEESC_RKNSA_9FieldTypeEj @ 0x0000000032500555 6. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000088478d4 7. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008832c1f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:47:36.708931 [ 4841 ] {5f8feced-a6f7-4370-826a-ea8a2e932085} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal64('4294967296', 0) AS x, toUInt32(x). (DECIMAL_OVERFLOW) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44452) (comment: 00700_decimal_casts_2.sql) (in query: SELECT toDecimal64('4294967296', 0) AS x, toUInt32(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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./src/Core/DecimalFunctions.h:346: _ZN2DB18convertFromDecimalINS_15DataTypeDecimalINS_7DecimalIlEEEENS_14DataTypeNumberIjEEQaa17IsDataTypeDecimalIT_E15is_arithmetic_vINT0_9FieldTypeEEEES9_RKNS7_9FieldTypeEj @ 0x0000000032500479 5. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000008845b34 6. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008832c1f 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 2025.10.23 23:47:36.711358 [ 4841 ] {5f8feced-a6f7-4370-826a-ea8a2e932085} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal64('4294967296', 0) AS x, toUInt32(x). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./src/Core/DecimalFunctions.h:346: _ZN2DB18convertFromDecimalINS_15DataTypeDecimalINS_7DecimalIlEEEENS_14DataTypeNumberIjEEQaa17IsDataTypeDecimalIT_E15is_arithmetic_vINT0_9FieldTypeEEEES9_RKNS7_9FieldTypeEj @ 0x0000000032500479 5. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000008845b34 6. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008832c1f 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 2025.10.23 23:47:36.797565 [ 4841 ] {50b36f52-858c-4067-a00c-488de94d374a} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal64('4294967296', 4) AS x, toUInt32(x). (DECIMAL_OVERFLOW) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44452) (comment: 00700_decimal_casts_2.sql) (in query: SELECT toDecimal64('4294967296', 4) AS x, toUInt32(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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./src/Core/DecimalFunctions.h:346: _ZN2DB18convertFromDecimalINS_15DataTypeDecimalINS_7DecimalIlEEEENS_14DataTypeNumberIjEEQaa17IsDataTypeDecimalIT_E15is_arithmetic_vINT0_9FieldTypeEEEES9_RKNS7_9FieldTypeEj @ 0x0000000032500479 5. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000008845b34 6. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008832c1f 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 2025.10.23 23:47:36.853181 [ 4841 ] {50b36f52-858c-4067-a00c-488de94d374a} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal64('4294967296', 4) AS x, toUInt32(x). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./src/Core/DecimalFunctions.h:346: _ZN2DB18convertFromDecimalINS_15DataTypeDecimalINS_7DecimalIlEEEENS_14DataTypeNumberIjEEQaa17IsDataTypeDecimalIT_E15is_arithmetic_vINT0_9FieldTypeEEEES9_RKNS7_9FieldTypeEj @ 0x0000000032500479 5. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000008845b34 6. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008832c1f 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 2025.10.23 23:47:37.001521 [ 3244 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:37.002446 [ 3258 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:37.145283 [ 4841 ] {3342fbff-3e69-4827-8111-57638485e12d} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('65536', 0) AS x, toUInt16(x). (DECIMAL_OVERFLOW) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44452) (comment: 00700_decimal_casts_2.sql) (in query: SELECT toDecimal128('65536', 0) AS x, toUInt16(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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./src/Core/DecimalFunctions.h:346: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, unsigned short&) @ 0x00000000324f622d 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:236: _ZN2DB18convertFromDecimalINS_15DataTypeDecimalINS_7DecimalIN4wide7integerILm128EiEEEEEENS_14DataTypeNumberItEEQaa17IsDataTypeDecimalIT_E15is_arithmetic_vINT0_9FieldTypeEEEESC_RKNSA_9FieldTypeEj @ 0x00000000324ff5d4 6. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt16, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt16, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000087ee714 7. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt16, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087d97df 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:47:37.147495 [ 4841 ] {3342fbff-3e69-4827-8111-57638485e12d} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('65536', 0) AS x, toUInt16(x). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./src/Core/DecimalFunctions.h:346: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, unsigned short&) @ 0x00000000324f622d 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:236: _ZN2DB18convertFromDecimalINS_15DataTypeDecimalINS_7DecimalIN4wide7integerILm128EiEEEEEENS_14DataTypeNumberItEEQaa17IsDataTypeDecimalIT_E15is_arithmetic_vINT0_9FieldTypeEEEESC_RKNSA_9FieldTypeEj @ 0x00000000324ff5d4 6. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt16, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt16, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000087ee714 7. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt16, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087d97df 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:47:37.214928 [ 3241 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:37.289845 [ 3237 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:37.311273 [ 4841 ] {987174c3-fba0-4365-bf12-fac4dd0b05a4} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('65536', 10) AS x, toUInt16(x). (DECIMAL_OVERFLOW) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44452) (comment: 00700_decimal_casts_2.sql) (in query: SELECT toDecimal128('65536', 10) AS x, toUInt16(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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./src/Core/DecimalFunctions.h:346: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, unsigned short&) @ 0x00000000324f622d 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:236: _ZN2DB18convertFromDecimalINS_15DataTypeDecimalINS_7DecimalIN4wide7integerILm128EiEEEEEENS_14DataTypeNumberItEEQaa17IsDataTypeDecimalIT_E15is_arithmetic_vINT0_9FieldTypeEEEESC_RKNSA_9FieldTypeEj @ 0x00000000324ff5d4 6. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt16, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt16, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000087ee714 7. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt16, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087d97df 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:47:37.313706 [ 4841 ] {987174c3-fba0-4365-bf12-fac4dd0b05a4} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('65536', 10) AS x, toUInt16(x). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./src/Core/DecimalFunctions.h:346: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, unsigned short&) @ 0x00000000324f622d 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:236: _ZN2DB18convertFromDecimalINS_15DataTypeDecimalINS_7DecimalIN4wide7integerILm128EiEEEEEENS_14DataTypeNumberItEEQaa17IsDataTypeDecimalIT_E15is_arithmetic_vINT0_9FieldTypeEEEESC_RKNSA_9FieldTypeEj @ 0x00000000324ff5d4 6. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt16, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt16, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000087ee714 7. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt16, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087d97df 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:47:37.541216 [ 3230 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:37.579869 [ 3229 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:37.599199 [ 4841 ] {3c700b9e-9c74-4e23-9e4d-2a050d18426f} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal64('65536', 0) AS x, toUInt16(x). (DECIMAL_OVERFLOW) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44452) (comment: 00700_decimal_casts_2.sql) (in query: SELECT toDecimal64('65536', 0) AS x, toUInt16(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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./src/Core/DecimalFunctions.h:346: _ZN2DB18convertFromDecimalINS_15DataTypeDecimalINS_7DecimalIlEEEENS_14DataTypeNumberItEEQaa17IsDataTypeDecimalIT_E15is_arithmetic_vINT0_9FieldTypeEEEES9_RKNS7_9FieldTypeEj @ 0x00000000324ff503 5. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt16, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt16, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000087ec854 6. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt16, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087d97df 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 2025.10.23 23:47:37.601816 [ 4841 ] {3c700b9e-9c74-4e23-9e4d-2a050d18426f} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal64('65536', 0) AS x, toUInt16(x). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./src/Core/DecimalFunctions.h:346: _ZN2DB18convertFromDecimalINS_15DataTypeDecimalINS_7DecimalIlEEEENS_14DataTypeNumberItEEQaa17IsDataTypeDecimalIT_E15is_arithmetic_vINT0_9FieldTypeEEEES9_RKNS7_9FieldTypeEj @ 0x00000000324ff503 5. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt16, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt16, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000087ec854 6. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt16, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087d97df 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 2025.10.23 23:47:37.748249 [ 4841 ] {641d88f0-c0db-425b-aa30-b4c820ca1151} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal64('65536', 4) AS x, toUInt16(x). (DECIMAL_OVERFLOW) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44452) (comment: 00700_decimal_casts_2.sql) (in query: SELECT toDecimal64('65536', 4) AS x, toUInt16(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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./src/Core/DecimalFunctions.h:346: _ZN2DB18convertFromDecimalINS_15DataTypeDecimalINS_7DecimalIlEEEENS_14DataTypeNumberItEEQaa17IsDataTypeDecimalIT_E15is_arithmetic_vINT0_9FieldTypeEEEES9_RKNS7_9FieldTypeEj @ 0x00000000324ff503 5. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt16, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt16, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000087ec854 6. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt16, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087d97df 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 2025.10.23 23:47:37.750434 [ 4841 ] {641d88f0-c0db-425b-aa30-b4c820ca1151} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal64('65536', 4) AS x, toUInt16(x). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./src/Core/DecimalFunctions.h:346: _ZN2DB18convertFromDecimalINS_15DataTypeDecimalINS_7DecimalIlEEEENS_14DataTypeNumberItEEQaa17IsDataTypeDecimalIT_E15is_arithmetic_vINT0_9FieldTypeEEEES9_RKNS7_9FieldTypeEj @ 0x00000000324ff503 5. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt16, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt16, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000087ec854 6. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt16, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087d97df 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 2025.10.23 23:47:38.002475 [ 3221 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:38.003359 [ 3216 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:38.216048 [ 3204 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:38.280872 [ 29264 ] {37ebccc4-86fc-4c1d-9b88-d766da42d823} executeQuery: Code: 107. DB::Exception: Can not match any files with path test_02481_mismatch_filesxxx*: The table structure cannot be extracted from a Parquet format file. You can specify the structure manually. (FILE_DOESNT_EXIST) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:50498) (comment: 02481_s3_throw_if_mismatch_files.sql) (in query: select a, b from s3(s3_conn, filename='test_02481_mismatch_filesxxx*', format=Parquet) settings s3_throw_on_zero_files_match=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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSource.cpp:549: DB::StorageObjectStorageSource::GlobIterator::nextImpl(unsigned long) @ 0x0000000030a2d308 5. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSource.cpp:468: DB::StorageObjectStorageSource::IIterator::next(unsigned long) @ 0x0000000030a268d4 6. ./build_docker/./src/Storages/ObjectStorage/ReadBufferIterator.cpp:0: DB::ReadBufferIterator::next() @ 0x0000000030a06de4 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003adb3fda 8. ./src/Storages/ColumnsDescription.h:113: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003adc5f55 9. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:0: DB::StorageObjectStorage::resolveSchemaFromData(std::shared_ptr const&, std::shared_ptr const&, std::optional const&, String&, std::shared_ptr const&) @ 0x00000000309f2747 10. ./build_docker/./src/Storages/ObjectStorage/Utils.cpp:0: DB::resolveSchemaAndFormat(DB::ColumnsDescription&, String&, std::shared_ptr, std::shared_ptr const&, std::optional, String&, std::shared_ptr const&) @ 0x0000000030a8098e 11. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:86: DB::StorageObjectStorage::StorageObjectStorage(std::shared_ptr, std::shared_ptr, std::shared_ptr, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::optional, bool, std::shared_ptr) @ 0x00000000309e8c1d 12. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageObjectStorage* std::construct_at[abi:v15007]&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, bool, std::nullptr_t, DB::StorageObjectStorage*>(DB::StorageObjectStorage*, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, bool&&, std::nullptr_t&&) @ 0x000000002ff29719 13. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, bool, std::nullptr_t, void>(std::allocator const&, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, bool&&, std::nullptr_t&&) @ 0x000000002ff28ffd 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionObjectStorage::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002fef4266 15. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f70b3 16. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000003374cff2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4838: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003345fff3 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334edd21 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436960 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:47:38.283970 [ 29264 ] {37ebccc4-86fc-4c1d-9b88-d766da42d823} TCPHandler: Code: 107. DB::Exception: Can not match any files with path test_02481_mismatch_filesxxx*: The table structure cannot be extracted from a Parquet format file. You can specify the structure manually. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSource.cpp:549: DB::StorageObjectStorageSource::GlobIterator::nextImpl(unsigned long) @ 0x0000000030a2d308 5. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSource.cpp:468: DB::StorageObjectStorageSource::IIterator::next(unsigned long) @ 0x0000000030a268d4 6. ./build_docker/./src/Storages/ObjectStorage/ReadBufferIterator.cpp:0: DB::ReadBufferIterator::next() @ 0x0000000030a06de4 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003adb3fda 8. ./src/Storages/ColumnsDescription.h:113: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003adc5f55 9. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:0: DB::StorageObjectStorage::resolveSchemaFromData(std::shared_ptr const&, std::shared_ptr const&, std::optional const&, String&, std::shared_ptr const&) @ 0x00000000309f2747 10. ./build_docker/./src/Storages/ObjectStorage/Utils.cpp:0: DB::resolveSchemaAndFormat(DB::ColumnsDescription&, String&, std::shared_ptr, std::shared_ptr const&, std::optional, String&, std::shared_ptr const&) @ 0x0000000030a8098e 11. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:86: DB::StorageObjectStorage::StorageObjectStorage(std::shared_ptr, std::shared_ptr, std::shared_ptr, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::optional, bool, std::shared_ptr) @ 0x00000000309e8c1d 12. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageObjectStorage* std::construct_at[abi:v15007]&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, bool, std::nullptr_t, DB::StorageObjectStorage*>(DB::StorageObjectStorage*, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, bool&&, std::nullptr_t&&) @ 0x000000002ff29719 13. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, bool, std::nullptr_t, void>(std::allocator const&, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, bool&&, std::nullptr_t&&) @ 0x000000002ff28ffd 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionObjectStorage::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002fef4266 15. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f70b3 16. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000003374cff2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4838: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003345fff3 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334edd21 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436960 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:47:38.291193 [ 3196 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:38.542324 [ 3208 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:38.580960 [ 3199 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:38.597867 [ 3894 ] {0894cdf2-00ce-4dfe-9f30-aa0dcc2e8edf} executeQuery: Code: 36. DB::Exception: Columns: a listed both in columns to sum and in partition key. That is not allowed. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44706) (comment: 01373_summing_merge_tree_explicit_columns_definition.sql) (in query: CREATE TABLE tt_error_1373 (`a` Int64, `d` Int64, `val` Int64) ENGINE = SummingMergeTree((a, val)) PARTITION BY a ORDER BY d SETTINGS index_granularity = 17119, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.10073811560869217, replace_long_file_name_to_hash = true, max_file_name_length = 66, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 168968965, compact_parts_max_granules_to_buffer = 122, compact_parts_merge_max_bytes_to_prefetch_part = 32480766, merge_max_block_size = 22547, old_parts_lifetime = 429., prefer_fetch_merged_part_size_threshold = 6597904406, vertical_merge_algorithm_min_rows_to_activate = 944140, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 9424103022, index_granularity_bytes = 4111253, concurrent_part_removal_threshold = 90, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 20381, primary_key_compress_block_size = 71229), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1079: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x00000000396c55c7 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:405: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x00000000396bdeb4 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:96: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000003a2e5c10 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a2e404f 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2d3063 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7b27a 10. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x0000000038308626 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348e414c 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 2025.10.23 23:47:38.599636 [ 3894 ] {0894cdf2-00ce-4dfe-9f30-aa0dcc2e8edf} TCPHandler: Code: 36. DB::Exception: Columns: a listed both in columns to sum and in partition key. That is not allowed. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1079: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x00000000396c55c7 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:405: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x00000000396bdeb4 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:96: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000003a2e5c10 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a2e404f 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2d3063 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7b27a 10. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x0000000038308626 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348e414c 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 2025.10.23 23:47:39.003610 [ 3188 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:39.004404 [ 3186 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:39.217184 [ 3173 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:39.292921 [ 3172 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:39.543554 [ 3176 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:39.582152 [ 3167 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:40.005219 [ 3144 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:40.005801 [ 3146 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:40.205618 [ 29264 ] {b0951277-dc87-44d8-b1da-76e7c2f96e57} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:53442) (comment: 01891_not_in_partition_prune.sql) (in query: SELECT count() AS `count()` FROM `test_15`.`test1` AS `__table1` WHERE `__table1`.`i` NOT IN (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202dea34 6. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039a5dbc5 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003bf2b229 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bf26bba 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003bf26345 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bf3d5b9 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2045: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf42fe0 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be48783 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003beb6da5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034cf5e6d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034cf5881 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:47:40.210149 [ 29264 ] {b0951277-dc87-44d8-b1da-76e7c2f96e57} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202dea34 6. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039a5dbc5 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003bf2b229 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bf26bba 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003bf26345 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bf3d5b9 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2045: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf42fe0 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be48783 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003beb6da5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034cf5e6d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034cf5881 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:47:40.216174 [ 3894 ] {0060583d-17ce-4892-9b49-2795e1fc084b} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.4:9000. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=0). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202dea34 6. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039a5dbc5 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003bf2b229 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bf26bba 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003bf26345 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bf3d5b9 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2045: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf42fe0 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be48783 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003beb6da5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034cf5e6d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034cf5881 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44722) (comment: 01891_not_in_partition_prune.sql) (in query: select count() from test1 where i not in (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002019af32 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000003a7e3e0c 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::Connection::receivePacket() @ 0x000000003a7ff61b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:340: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003a8df9b9 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:0: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000032358b71 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000323566d1 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032355a26 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000032352f12 2025.10.23 23:47:40.218210 [ 3137 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:40.223184 [ 3894 ] {0060583d-17ce-4892-9b49-2795e1fc084b} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.4:9000. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=0). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202dea34 6. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039a5dbc5 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003bf2b229 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bf26bba 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003bf26345 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bf3d5b9 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2045: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf42fe0 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be48783 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003beb6da5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034cf5e6d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034cf5881 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 : 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002019af32 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000003a7e3e0c 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::Connection::receivePacket() @ 0x000000003a7ff61b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:340: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003a8df9b9 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:0: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000032358b71 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000323566d1 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032355a26 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000032352f12 2025.10.23 23:47:40.294009 [ 3177 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:40.544997 [ 3140 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:40.583286 [ 3118 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:40.916488 [ 3894 ] {8eda5695-85d7-4102-85d8-8ea8f7bd6fb0} executeQuery: Code: 57. DB::Exception: Table test_15.test already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44730) (comment: 02949_parallel_replicas_scalar_subquery_big_integer.sql) (in query: CREATE TABLE test (`x` UInt8) ENGINE = MergeTree ORDER BY x SETTINGS index_granularity = 24900, min_bytes_for_wide_part = 489117754, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 116, min_bytes_for_full_part_storage = 49736001, compact_parts_max_bytes_to_buffer = 247371574, compact_parts_max_granules_to_buffer = 71, compact_parts_merge_max_bytes_to_prefetch_part = 11875854, merge_max_block_size = 1715, old_parts_lifetime = 421., prefer_fetch_merged_part_size_threshold = 9424241359, vertical_merge_algorithm_min_rows_to_activate = 574471, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 25659179, concurrent_part_removal_threshold = 67, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 49271, primary_key_compress_block_size = 97436), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:47:40.919308 [ 3894 ] {8eda5695-85d7-4102-85d8-8ea8f7bd6fb0} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:47:41.006468 [ 3130 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:41.007075 [ 3113 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:41.219243 [ 3127 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:41.295159 [ 3112 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:41.546118 [ 3099 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:41.584550 [ 3102 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:41.919249 [ 4841 ] {062c26b1-bb40-4a85-8332-ad1b5119f182} executeQuery: Code: 407. DB::Exception: Decimal convert overflow: 2147483649 is not in range (-2147483648, 2147483647): In scope SELECT toInt64('2147483649') AS x, toDecimal32(x, 0). (DECIMAL_OVERFLOW) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44452) (comment: 00700_decimal_casts_2.sql) (in query: SELECT toInt64('2147483649') AS x, toDecimal32(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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x000000000861dc7f 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:154: _ZN2DB19convertDecimalsImplINS_15DataTypeDecimalINS_7DecimalIlEEEENS1_INS2_IiEEEEvQaa17IsDataTypeDecimalIT_E17IsDataTypeDecimalIT0_EEET1_RKNS7_9FieldTypeEjjRNS8_9FieldTypeE @ 0x00000000324e645b 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:322: _ZN2DB16convertToDecimalINS_14DataTypeNumberIlEENS_15DataTypeDecimalINS_7DecimalIiEEEEQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEENS9_9FieldTypeERKS8_j @ 0x000000003250acae 6. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000091fcef2 7. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091c90df 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:47:42.008237 [ 3100 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:42.008861 [ 3094 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:42.017950 [ 4841 ] {062c26b1-bb40-4a85-8332-ad1b5119f182} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow: 2147483649 is not in range (-2147483648, 2147483647): In scope SELECT toInt64('2147483649') AS x, toDecimal32(x, 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x000000000861dc7f 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:154: _ZN2DB19convertDecimalsImplINS_15DataTypeDecimalINS_7DecimalIlEEEENS1_INS2_IiEEEEvQaa17IsDataTypeDecimalIT_E17IsDataTypeDecimalIT0_EEET1_RKNS7_9FieldTypeEjjRNS8_9FieldTypeE @ 0x00000000324e645b 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:322: _ZN2DB16convertToDecimalINS_14DataTypeNumberIlEENS_15DataTypeDecimalINS_7DecimalIiEEEEQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEENS9_9FieldTypeERKS8_j @ 0x000000003250acae 6. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000091fcef2 7. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091c90df 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:47:42.087123 [ 4841 ] {97034c89-41bb-4dea-b2e7-aff480601490} executeQuery: Code: 407. DB::Exception: Decimal convert overflow: -2147483649 is not in range (-2147483648, 2147483647): In scope SELECT toInt64('-2147483649') AS x, toDecimal32(x, 0). (DECIMAL_OVERFLOW) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44452) (comment: 00700_decimal_casts_2.sql) (in query: SELECT toInt64('-2147483649') AS x, toDecimal32(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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x000000000861dc7f 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:154: _ZN2DB19convertDecimalsImplINS_15DataTypeDecimalINS_7DecimalIlEEEENS1_INS2_IiEEEEvQaa17IsDataTypeDecimalIT_E17IsDataTypeDecimalIT0_EEET1_RKNS7_9FieldTypeEjjRNS8_9FieldTypeE @ 0x00000000324e645b 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:322: _ZN2DB16convertToDecimalINS_14DataTypeNumberIlEENS_15DataTypeDecimalINS_7DecimalIiEEEEQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEENS9_9FieldTypeERKS8_j @ 0x000000003250acae 6. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000091fcef2 7. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091c90df 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:47:42.089756 [ 4841 ] {97034c89-41bb-4dea-b2e7-aff480601490} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow: -2147483649 is not in range (-2147483648, 2147483647): In scope SELECT toInt64('-2147483649') AS x, toDecimal32(x, 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x000000000861dc7f 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:154: _ZN2DB19convertDecimalsImplINS_15DataTypeDecimalINS_7DecimalIlEEEENS1_INS2_IiEEEEvQaa17IsDataTypeDecimalIT_E17IsDataTypeDecimalIT0_EEET1_RKNS7_9FieldTypeEjjRNS8_9FieldTypeE @ 0x00000000324e645b 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:322: _ZN2DB16convertToDecimalINS_14DataTypeNumberIlEENS_15DataTypeDecimalINS_7DecimalIiEEEEQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEENS9_9FieldTypeERKS8_j @ 0x000000003250acae 6. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000091fcef2 7. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091c90df 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:47:42.222887 [ 3092 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:42.296847 [ 3071 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:42.547080 [ 3081 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:42.585717 [ 3078 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:43.009089 [ 3064 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:43.010024 [ 3059 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:43.224258 [ 3065 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:43.298098 [ 3444 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:43.548420 [ 3427 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:43.586942 [ 3433 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:43.692857 [ 29264 ] {2310bb14-18f5-46af-a15a-b0b54fe501b6} executeQuery: Code: 264. DB::Exception: Table test_1.joinbug_join (61c762c7-70b7-4a24-9cff-97459edb41a8) needs the same join_use_nulls setting as present in LEFT or FULL JOIN. (INCOMPATIBLE_TYPE_OF_JOIN) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44742) (comment: 00561_storage_join.sql) (in query: select id, id2, val, val2, created from ( SELECT toUInt64(arrayJoin(range(50))) AS id2 ) js1 SEMI LEFT JOIN joinbug_join using id2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Storages/StorageJoin.cpp:239: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x0000000038412c84 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&) @ 0x0000000034de998c 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&) @ 0x0000000034d95d85 7. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d6a797 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0b8de 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cfd8b2 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034cf6172 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5bf1 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:47:43.694494 [ 29264 ] {2310bb14-18f5-46af-a15a-b0b54fe501b6} TCPHandler: Code: 264. DB::Exception: Table test_1.joinbug_join (61c762c7-70b7-4a24-9cff-97459edb41a8) needs the same join_use_nulls setting as present in LEFT or FULL JOIN. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Storages/StorageJoin.cpp:239: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x0000000038412c84 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&) @ 0x0000000034de998c 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&) @ 0x0000000034d95d85 7. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d6a797 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0b8de 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cfd8b2 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034cf6172 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5bf1 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:47:43.822571 [ 3894 ] {8717106b-f9a0-47bc-a1dc-f4fb4f32f3e4} executeQuery: Code: 48. DB::Exception: Conversion between numeric types and UUID is not supported. Probably the passed UUID is unquoted: In scope SELECT toUUID(-1.1). (NOT_IMPLEMENTED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44738) (comment: 01634_uuid_fuzz.sql) (in query: SELECT toUUID(-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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 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&&) @ 0x0000000008f596f1 5. DB::(anonymous namespace)::FunctionConvert>>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008f3aaff 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 2025.10.23 23:47:43.824437 [ 3894 ] {8717106b-f9a0-47bc-a1dc-f4fb4f32f3e4} TCPHandler: Code: 48. DB::Exception: Conversion between numeric types and UUID is not supported. Probably the passed UUID is unquoted: In scope SELECT toUUID(-1.1). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 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&&) @ 0x0000000008f596f1 5. DB::(anonymous namespace)::FunctionConvert>>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008f3aaff 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 2025.10.23 23:47:44.010152 [ 3265 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:44.011019 [ 3296 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:44.225180 [ 3124 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:44.299058 [ 3174 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:44.469135 [ 3894 ] {655b17c4-6996-4623-9dbc-7e90600470b9} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=748). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44758) (comment: 01300_polygon_convex_hull.sql) (in query: select polygonConvexHullCartesian([[[(0., 0.), (0., 5.), (5., 5.), (5., 0.), (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:47:44.473593 [ 3894 ] {655b17c4-6996-4623-9dbc-7e90600470b9} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=748). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:47:44.549590 [ 3538 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:44.588499 [ 3564 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:45.011249 [ 3565 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:45.012393 [ 3552 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:45.227149 [ 3074 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:45.234321 [ 4841 ] {e18d5f9d-d9e7-47bc-8773-dfb8fc687c51} executeQuery: Code: 407. DB::Exception: Decimal convert overflow: 2147483649 is not in range (-2147483648, 2147483647): In scope SELECT toUInt64('2147483649') AS x, toDecimal32(x, 0). (DECIMAL_OVERFLOW) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44452) (comment: 00700_decimal_casts_2.sql) (in query: SELECT toUInt64('2147483649') AS x, toDecimal32(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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x000000000861dc7f 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:154: _ZN2DB19convertDecimalsImplINS_15DataTypeDecimalINS_7DecimalIN4wide7integerILm128EiEEEEEENS1_INS2_IiEEEEvQaa17IsDataTypeDecimalIT_E17IsDataTypeDecimalIT0_EEET1_RKNSA_9FieldTypeEjjRNSB_9FieldTypeE @ 0x00000000324e73be 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:322: _ZN2DB16convertToDecimalINS_14DataTypeNumberImEENS_15DataTypeDecimalINS_7DecimalIiEEEEQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEENS9_9FieldTypeERKS8_j @ 0x000000003250adc4 6. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000091fa022 7. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091c90df 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:47:45.237288 [ 4841 ] {e18d5f9d-d9e7-47bc-8773-dfb8fc687c51} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow: 2147483649 is not in range (-2147483648, 2147483647): In scope SELECT toUInt64('2147483649') AS x, toDecimal32(x, 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x000000000861dc7f 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:154: _ZN2DB19convertDecimalsImplINS_15DataTypeDecimalINS_7DecimalIN4wide7integerILm128EiEEEEEENS1_INS2_IiEEEEvQaa17IsDataTypeDecimalIT_E17IsDataTypeDecimalIT0_EEET1_RKNSA_9FieldTypeEjjRNSB_9FieldTypeE @ 0x00000000324e73be 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:322: _ZN2DB16convertToDecimalINS_14DataTypeNumberImEENS_15DataTypeDecimalINS_7DecimalIiEEEEQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEENS9_9FieldTypeERKS8_j @ 0x000000003250adc4 6. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000091fa022 7. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091c90df 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:47:45.300237 [ 3543 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:45.550692 [ 3558 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:45.589590 [ 3548 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:46.012574 [ 3519 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:46.013470 [ 3523 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:46.228627 [ 3515 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:46.301606 [ 3514 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:46.552032 [ 3509 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:46.590696 [ 3506 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:47.013387 [ 3522 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:47.014566 [ 3503 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:47.229904 [ 3495 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:47.302980 [ 3502 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:47.553095 [ 3488 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:47.592199 [ 3487 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:48.014161 [ 3490 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:48.015497 [ 3477 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:48.033914 [ 3656 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b37203c3-8fb0-4cdf-8555-9946d278f55b::202510_86_131_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 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) @ 0x0000000039c89948 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000003999bfb7 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 @ 0x00000000399942f0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000039d15c04 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&) @ 0x0000000039d20399 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) @ 0x0000000039d1c606 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000396308a4 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x00000000396235dd 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000003963b3e0 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x00000000396504a0 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3c455d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:48.230834 [ 3467 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:48.304374 [ 3466 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:48.553935 [ 3471 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:48.593593 [ 3460 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:48.641556 [ 4841 ] {93e0c421-fafe-4883-89b1-6a9a63300005} executeQuery: Code: 407. DB::Exception: Decimal convert overflow: 9223372036854775809 is not in range (-9223372036854775808, 9223372036854775807): In scope SELECT toUInt64('9223372036854775809') AS x, toDecimal64(x, 0). (DECIMAL_OVERFLOW) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44452) (comment: 00700_decimal_casts_2.sql) (in query: SELECT toUInt64('9223372036854775809') AS x, toDecimal64(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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x000000000861dc7f 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:154: _ZN2DB19convertDecimalsImplINS_15DataTypeDecimalINS_7DecimalIN4wide7integerILm128EiEEEEEENS1_INS2_IlEEEEvQaa17IsDataTypeDecimalIT_E17IsDataTypeDecimalIT0_EEET1_RKNSA_9FieldTypeEjjRNSB_9FieldTypeE @ 0x00000000324eaa5a 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:322: _ZN2DB16convertToDecimalINS_14DataTypeNumberImEENS_15DataTypeDecimalINS_7DecimalIlEEEEQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEENS9_9FieldTypeERKS8_j @ 0x000000003250bc44 6. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000924b50d 7. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000921d09f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:47:48.644528 [ 4841 ] {93e0c421-fafe-4883-89b1-6a9a63300005} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow: 9223372036854775809 is not in range (-9223372036854775808, 9223372036854775807): In scope SELECT toUInt64('9223372036854775809') AS x, toDecimal64(x, 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x000000000861dc7f 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:154: _ZN2DB19convertDecimalsImplINS_15DataTypeDecimalINS_7DecimalIN4wide7integerILm128EiEEEEEENS1_INS2_IlEEEEvQaa17IsDataTypeDecimalIT_E17IsDataTypeDecimalIT0_EEET1_RKNSA_9FieldTypeEjjRNSB_9FieldTypeE @ 0x00000000324eaa5a 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:322: _ZN2DB16convertToDecimalINS_14DataTypeNumberImEENS_15DataTypeDecimalINS_7DecimalIlEEEEQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEENS9_9FieldTypeERKS8_j @ 0x000000003250bc44 6. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000924b50d 7. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000921d09f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:47:49.015050 [ 3446 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:49.016300 [ 3445 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:49.040463 [ 2903 ] {021ed5ad-f2f5-43a8-99db-61b239147565} executeQuery: Code: 62. DB::Exception: When creating a materialized view you can't declare both 'TO [db].[table]' and 'EMPTY'. (SYNTAX_ERROR) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:47138) (comment: 02900_matview_create_to_errors.sh) (in query: create materialized view aaaa TO b EMPTY as Select * from 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Parsers/ParserCreateQuery.cpp:0: DB::ParserCreateViewQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d0c499b 5. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d075c6e 6. ./build_docker/./src/Parsers/ParserCreateQuery.cpp:1866: DB::ParserCreateQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d0ca057 7. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d075c6e 8. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:88: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d109160 9. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d075c6e 10. ./build_docker/./src/Parsers/ParserQuery.cpp:0: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d0f8187 11. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d075c6e 12. ./build_docker/./src/Parsers/parseQuery.cpp:0: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x000000003d1b92b1 13. ./build_docker/./src/Parsers/parseQuery.cpp:0: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003d1bccf0 14. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003d1bd031 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358ad0d2 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 17. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 18. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 19. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:47:49.043940 [ 2903 ] {021ed5ad-f2f5-43a8-99db-61b239147565} DynamicQueryHandler: Code: 62. DB::Exception: When creating a materialized view you can't declare both 'TO [db].[table]' and 'EMPTY'. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Parsers/ParserCreateQuery.cpp:0: DB::ParserCreateViewQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d0c499b 5. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d075c6e 6. ./build_docker/./src/Parsers/ParserCreateQuery.cpp:1866: DB::ParserCreateQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d0ca057 7. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d075c6e 8. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:88: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d109160 9. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d075c6e 10. ./build_docker/./src/Parsers/ParserQuery.cpp:0: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d0f8187 11. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d075c6e 12. ./build_docker/./src/Parsers/parseQuery.cpp:0: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x000000003d1b92b1 13. ./build_docker/./src/Parsers/parseQuery.cpp:0: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003d1bccf0 14. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003d1bd031 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358ad0d2 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 17. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 18. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 19. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:49.231813 [ 3434 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:49.305551 [ 3429 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:49.554867 [ 3432 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:49.594845 [ 3430 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:50.017437 [ 3422 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:50.077954 [ 3416 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:50.232743 [ 3417 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:50.306586 [ 3421 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:50.555861 [ 3407 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:50.596271 [ 3405 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:50.721877 [ 3894 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:50.748722 [ 3894 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:50.766197 [ 29264 ] {f30c6dd5-32ac-4862-ad0c-42a3200ff928} executeQuery: Code: 62. DB::Exception: When creating a materialized view you can't declare both 'TO [db].[table]' and 'POPULATE'. (SYNTAX_ERROR) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:47158) (comment: 02900_matview_create_to_errors.sh) (in query: create materialized view aaaa TO b POPULATE as Select * from 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Parsers/ParserCreateQuery.cpp:0: DB::ParserCreateViewQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d0c4731 5. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d075c6e 6. ./build_docker/./src/Parsers/ParserCreateQuery.cpp:1866: DB::ParserCreateQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d0ca057 7. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d075c6e 8. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:88: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d109160 9. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d075c6e 10. ./build_docker/./src/Parsers/ParserQuery.cpp:0: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d0f8187 11. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d075c6e 12. ./build_docker/./src/Parsers/parseQuery.cpp:0: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x000000003d1b92b1 13. ./build_docker/./src/Parsers/parseQuery.cpp:0: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003d1bccf0 14. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003d1bd031 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358ad0d2 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 17. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 18. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 19. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:47:50.769619 [ 29264 ] {f30c6dd5-32ac-4862-ad0c-42a3200ff928} DynamicQueryHandler: Code: 62. DB::Exception: When creating a materialized view you can't declare both 'TO [db].[table]' and 'POPULATE'. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Parsers/ParserCreateQuery.cpp:0: DB::ParserCreateViewQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d0c4731 5. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d075c6e 6. ./build_docker/./src/Parsers/ParserCreateQuery.cpp:1866: DB::ParserCreateQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d0ca057 7. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d075c6e 8. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:88: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d109160 9. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d075c6e 10. ./build_docker/./src/Parsers/ParserQuery.cpp:0: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d0f8187 11. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d075c6e 12. ./build_docker/./src/Parsers/parseQuery.cpp:0: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x000000003d1b92b1 13. ./build_docker/./src/Parsers/parseQuery.cpp:0: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003d1bccf0 14. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003d1bd031 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358ad0d2 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 17. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 18. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 19. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:50.773840 [ 3894 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:50.794716 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:50.817047 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:50.834498 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:50.854585 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:50.873313 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:50.893053 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:50.911546 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:50.936003 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:50.959058 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:50.975433 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:51.019042 [ 3384 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:51.075321 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:51.079084 [ 3392 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:51.197546 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:51.218970 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:51.233790 [ 3387 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:51.308168 [ 3386 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:51.318895 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:51.356150 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:51.432820 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:51.544366 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:51.556887 [ 3388 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:51.566820 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:51.588956 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:51.597615 [ 3381 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:51.617885 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:51.644823 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:51.666770 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:51.692412 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:51.803647 [ 4841 ] {640495c6-10df-4944-ac95-05dc6d55bb66} executeQuery: Code: 44. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal32'. Expected: const Integer, got: UInt64: In scope SELECT toDecimal32(0, rowNumberInBlock()). (ILLEGAL_COLUMN) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44452) (comment: 00700_decimal_casts_2.sql) (in query: SELECT toDecimal32(0, rowNumberInBlock());), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084076a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000084008e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fefba 6. std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x000000000921be03 7. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::getReturnTypeImpl(std::vector> const&) const @ 0x00000000091cac15 8. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083d29bf 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60aa37 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b609cba 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60b9ac 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334af94d 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 2025.10.23 23:47:51.853269 [ 4841 ] {640495c6-10df-4944-ac95-05dc6d55bb66} TCPHandler: Code: 44. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal32'. Expected: const Integer, got: UInt64: In scope SELECT toDecimal32(0, rowNumberInBlock()). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084076a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000084008e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fefba 6. std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x000000000921be03 7. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::getReturnTypeImpl(std::vector> const&) const @ 0x00000000091cac15 8. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083d29bf 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60aa37 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b609cba 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60b9ac 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334af94d 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 2025.10.23 23:47:51.868614 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:51.890894 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:52.015189 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:52.020497 [ 3376 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:52.040598 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:52.066061 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:52.080312 [ 3374 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:52.139221 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:52.164101 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:52.181355 [ 3645 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {d60c8165-1f8c-4cd1-8084-8b8c63363ea3::202510_99_127_18}: 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 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) @ 0x0000000039c89948 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000003999bfb7 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 @ 0x00000000399942f0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000039d15c04 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&) @ 0x0000000039d20399 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) @ 0x0000000039d1c606 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000396308a4 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x00000000396235dd 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000003963b3e0 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x00000000396504a0 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3c455d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:52.190457 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:52.235000 [ 3363 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:52.303090 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:52.309660 [ 3357 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:52.329020 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:52.353012 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:52.376246 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:52.401256 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:52.425141 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:52.456521 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:52.478987 [ 2903 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:52.496071 [ 2903 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:52.511571 [ 2903 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:52.529110 [ 2903 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:52.545479 [ 2903 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:52.557663 [ 3347 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:52.567286 [ 2903 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:52.598994 [ 3352 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:52.606731 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:52.629499 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:52.653757 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:52.708378 [ 2903 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:52.735136 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:52.765153 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:52.787213 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:52.814091 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:52.836576 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:52.857437 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:52.922348 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:53.021452 [ 3372 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:53.031737 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:53.049925 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:53.081426 [ 3328 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:53.121657 [ 3894 ] {547a6e16-8b16-446f-bb28-b64eec55f3e1} executeQuery: Code: 62. DB::Exception: When creating a materialized view you can't declare both 'TO [db].[table]' and 'ENGINE'. (SYNTAX_ERROR) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:47180) (comment: 02900_matview_create_to_errors.sh) (in query: create materialized view aaaa TO b ENGINE = MergeTree() as Select * from 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Parsers/ParserCreateQuery.cpp:0: DB::ParserCreateViewQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d0c45f1 5. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d075c6e 6. ./build_docker/./src/Parsers/ParserCreateQuery.cpp:1866: DB::ParserCreateQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d0ca057 7. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d075c6e 8. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:88: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d109160 9. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d075c6e 10. ./build_docker/./src/Parsers/ParserQuery.cpp:0: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d0f8187 11. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d075c6e 12. ./build_docker/./src/Parsers/parseQuery.cpp:0: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x000000003d1b92b1 13. ./build_docker/./src/Parsers/parseQuery.cpp:0: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003d1bccf0 14. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003d1bd031 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358ad0d2 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 17. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 18. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 19. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:47:53.125504 [ 3894 ] {547a6e16-8b16-446f-bb28-b64eec55f3e1} DynamicQueryHandler: Code: 62. DB::Exception: When creating a materialized view you can't declare both 'TO [db].[table]' and 'ENGINE'. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Parsers/ParserCreateQuery.cpp:0: DB::ParserCreateViewQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d0c45f1 5. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d075c6e 6. ./build_docker/./src/Parsers/ParserCreateQuery.cpp:1866: DB::ParserCreateQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d0ca057 7. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d075c6e 8. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:88: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d109160 9. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d075c6e 10. ./build_docker/./src/Parsers/ParserQuery.cpp:0: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d0f8187 11. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d075c6e 12. ./build_docker/./src/Parsers/parseQuery.cpp:0: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x000000003d1b92b1 13. ./build_docker/./src/Parsers/parseQuery.cpp:0: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003d1bccf0 14. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003d1bd031 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358ad0d2 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 17. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 18. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 19. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:53.148206 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:53.169501 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:53.219157 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:53.236138 [ 3323 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:53.289324 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:53.307379 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:53.310785 [ 3333 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:53.327008 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:53.344215 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:53.363286 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:53.384589 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:53.402130 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:53.422552 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:53.473527 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:53.557113 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:53.558693 [ 3332 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:53.578921 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:53.600102 [ 3316 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:53.760907 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:53.788503 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:53.893494 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:53.983266 [ 3894 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x00000000315a10ad 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159da2f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b6b4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa269fb 10. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:54.016628 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:54.022730 [ 3304 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:54.041881 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:54.067906 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:54.082410 [ 3310 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:54.108944 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:54.153681 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:54.179537 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:54.201049 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:54.229273 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:54.237360 [ 3301 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:54.254680 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:54.260657 [ 3894 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x00000000315a10ad 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159da2f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b6b4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa269fb 10. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:54.273653 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:54.291672 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:54.312230 [ 3298 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:54.389266 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:54.411074 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:54.432937 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:54.453513 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:54.476348 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:54.498500 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:54.518581 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:54.537117 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:54.558297 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:54.560165 [ 3300 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:54.580895 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:54.601010 [ 3302 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:54.601440 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:54.620569 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:54.640519 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:54.659811 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:54.679960 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:54.698516 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x00000000315a10ad 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159da2f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b6b4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa269fb 10. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:54.705085 [ 3894 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:54.805784 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:54.833135 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:54.928077 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:54.953570 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:54.979005 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:55.004149 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:55.024511 [ 3287 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:55.050659 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:55.083531 [ 3278 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:55.084144 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:55.111023 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:55.137371 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:55.162787 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:55.238602 [ 3279 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:55.240292 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:55.268424 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:55.296782 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:55.313546 [ 3281 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:55.324055 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:55.350410 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:55.446638 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:55.473430 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:55.501024 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:55.529815 [ 3894 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:55.556313 [ 3894 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:55.561311 [ 3268 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:55.582917 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:55.602044 [ 3266 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:55.611587 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:55.709360 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:55.732277 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:55.752203 [ 4841 ] {22d10ab1-e1a3-4f21-b0d0-2cbb9161b3a6} executeQuery: Code: 44. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal64'. Expected: const Integer, got: UInt64: In scope SELECT toDecimal64(0, rowNumberInBlock()). (ILLEGAL_COLUMN) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44452) (comment: 00700_decimal_casts_2.sql) (in query: SELECT toDecimal64(0, rowNumberInBlock());), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084076a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000084008e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fefba 6. std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x0000000009270603 7. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::getReturnTypeImpl(std::vector> const&) const @ 0x000000000921ebd5 8. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083d29bf 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60aa37 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b609cba 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60b9ac 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334af94d 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 2025.10.23 23:47:55.755114 [ 4841 ] {22d10ab1-e1a3-4f21-b0d0-2cbb9161b3a6} TCPHandler: Code: 44. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal64'. Expected: const Integer, got: UInt64: In scope SELECT toDecimal64(0, rowNumberInBlock()). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084076a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000084008e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fefba 6. std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x0000000009270603 7. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::getReturnTypeImpl(std::vector> const&) const @ 0x000000000921ebd5 8. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083d29bf 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60aa37 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b609cba 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60b9ac 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334af94d 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 2025.10.23 23:47:55.757882 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:55.868681 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:55.893147 [ 3894 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:55.920192 [ 3894 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:55.960834 [ 2903 ] {50f16104-4d17-410f-8530-128627941afb} executeQuery: Code: 62. DB::Exception: When creating a materialized view you can't declare both 'ENGINE' and 'TO [db].[table]'. (SYNTAX_ERROR) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:47684) (comment: 02900_matview_create_to_errors.sh) (in query: create materialized view aaaa ENGINE = MergeTree() TO b as Select * from 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Parsers/ParserCreateQuery.cpp:0: DB::ParserCreateViewQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d0c4865 5. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d075c6e 6. ./build_docker/./src/Parsers/ParserCreateQuery.cpp:1866: DB::ParserCreateQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d0ca057 7. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d075c6e 8. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:88: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d109160 9. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d075c6e 10. ./build_docker/./src/Parsers/ParserQuery.cpp:0: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d0f8187 11. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d075c6e 12. ./build_docker/./src/Parsers/parseQuery.cpp:0: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x000000003d1b92b1 13. ./build_docker/./src/Parsers/parseQuery.cpp:0: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003d1bccf0 14. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003d1bd031 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358ad0d2 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 17. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 18. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 19. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:47:55.965038 [ 2903 ] {50f16104-4d17-410f-8530-128627941afb} DynamicQueryHandler: Code: 62. DB::Exception: When creating a materialized view you can't declare both 'ENGINE' and 'TO [db].[table]'. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Parsers/ParserCreateQuery.cpp:0: DB::ParserCreateViewQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d0c4865 5. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d075c6e 6. ./build_docker/./src/Parsers/ParserCreateQuery.cpp:1866: DB::ParserCreateQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d0ca057 7. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d075c6e 8. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:88: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d109160 9. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d075c6e 10. ./build_docker/./src/Parsers/ParserQuery.cpp:0: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d0f8187 11. ./build_docker/./src/Parsers/IParserBase.cpp:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003d075c6e 12. ./build_docker/./src/Parsers/parseQuery.cpp:0: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x000000003d1b92b1 13. ./build_docker/./src/Parsers/parseQuery.cpp:0: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003d1bccf0 14. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003d1bd031 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358ad0d2 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 17. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 18. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 19. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:56.009593 [ 3894 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:56.025994 [ 3250 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:56.036787 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:56.063266 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:56.084910 [ 3271 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:56.087474 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:56.104765 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:56.122671 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:56.140889 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:56.239944 [ 3253 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:56.240580 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:56.259648 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:56.277272 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:56.299658 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:56.314494 [ 3254 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:56.318778 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:56.339293 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:56.359250 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:56.378991 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:56.399429 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:56.420753 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:56.438958 [ 29264 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000311f2821 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x00000000350967ef 5. ./contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000003ac73e90 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa1ca2a 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:56.562215 [ 3258 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:56.603187 [ 3247 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:57.027362 [ 3221 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:57.086026 [ 3216 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:57.240993 [ 3212 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:57.315311 [ 3194 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:57.563378 [ 3188 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:57.604164 [ 3181 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:58.028831 [ 3146 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:58.087126 [ 3142 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:58.166601 [ 4841 ] {c7bc48fb-e961-4758-a117-066c66f911be} executeQuery: Code: 44. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal128'. Expected: const Integer, got: UInt64: In scope SELECT toDecimal128(0, rowNumberInBlock()). (ILLEGAL_COLUMN) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44452) (comment: 00700_decimal_casts_2.sql) (in query: SELECT toDecimal128(0, rowNumberInBlock());), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084076a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000084008e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fefba 6. std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x00000000092c6583 7. DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::getReturnTypeImpl(std::vector> const&) const @ 0x00000000092733d5 8. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083d29bf 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60aa37 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b609cba 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60b9ac 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334af94d 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 2025.10.23 23:47:58.169013 [ 4841 ] {c7bc48fb-e961-4758-a117-066c66f911be} TCPHandler: Code: 44. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal128'. Expected: const Integer, got: UInt64: In scope SELECT toDecimal128(0, rowNumberInBlock()). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084076a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000084008e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fefba 6. std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x00000000092c6583 7. DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::getReturnTypeImpl(std::vector> const&) const @ 0x00000000092733d5 8. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083d29bf 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60aa37 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b609cba 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60b9ac 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334af94d 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 2025.10.23 23:47:58.241962 [ 3128 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:58.316502 [ 3121 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:58.564389 [ 3118 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:58.605416 [ 3115 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:59.030006 [ 3127 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:59.088143 [ 3112 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:59.242976 [ 3122 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:59.317752 [ 3110 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:59.565252 [ 3088 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:59.606453 [ 3076 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:00.030990 [ 3085 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:00.089095 [ 3075 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:00.244099 [ 3080 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:00.318743 [ 3077 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:00.381942 [ 3894 ] {54898e1d-d1ca-4a67-aced-01b29678eb3e} executeQuery: Code: 57. DB::Exception: Table system.columns already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:33682) (comment: 01445_create_table_as_table_function.sh) (in query: CREATE TABLE system.columns AS numbers(10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:48:00.384951 [ 3894 ] {54898e1d-d1ca-4a67-aced-01b29678eb3e} TCPHandler: Code: 57. DB::Exception: Table system.columns already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:48:00.566035 [ 3062 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:00.607277 [ 3068 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:01.032087 [ 3427 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:01.090129 [ 3443 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:01.245227 [ 3435 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:01.320132 [ 3345 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:01.566954 [ 3265 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:01.608325 [ 3322 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:01.964884 [ 4841 ] {1a8eb610-2683-4092-bedf-c7187bda87a7} executeQuery: Code: 407. DB::Exception: Decimal convert overflow. Cannot convert infinity or NaN to decimal: In scope SELECT toDecimal32(1 / 0, 0). (DECIMAL_OVERFLOW) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44452) (comment: 00700_decimal_casts_2.sql) (in query: SELECT toDecimal32(1/0, 0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008460d8a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:277: _ZN2DB20convertToDecimalImplINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIiEEEEvQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEET1_RKS8_jRNS9_9FieldTypeE @ 0x0000000032505b0b 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:322: _ZN2DB16convertToDecimalINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIiEEEEQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEENS9_9FieldTypeERKS8_j @ 0x000000003250b435 6. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000091f0fd3 7. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091c90df 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:48:01.967069 [ 4841 ] {1a8eb610-2683-4092-bedf-c7187bda87a7} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow. Cannot convert infinity or NaN to decimal: In scope SELECT toDecimal32(1 / 0, 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008460d8a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:277: _ZN2DB20convertToDecimalImplINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIiEEEEvQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEET1_RKS8_jRNS9_9FieldTypeE @ 0x0000000032505b0b 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:322: _ZN2DB16convertToDecimalINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIiEEEEQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEENS9_9FieldTypeERKS8_j @ 0x000000003250b435 6. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000091f0fd3 7. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091c90df 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:48:02.033449 [ 3141 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:02.090967 [ 3207 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:02.246699 [ 3562 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:02.321436 [ 3538 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:02.568187 [ 3560 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:02.609369 [ 3111 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:03.034450 [ 3534 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:03.159636 [ 3527 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:03.247580 [ 3532 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:03.322402 [ 3543 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:03.569095 [ 3566 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:03.610273 [ 3558 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:04.035403 [ 3523 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:04.160486 [ 3515 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:04.248694 [ 3539 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:04.323391 [ 3509 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:04.408792 [ 4841 ] {b5b24c98-5992-4439-85e4-47567cb1b356} executeQuery: Code: 407. DB::Exception: Decimal convert overflow. Cannot convert infinity or NaN to decimal: In scope SELECT toDecimal64(1 / 0, 1). (DECIMAL_OVERFLOW) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44452) (comment: 00700_decimal_casts_2.sql) (in query: SELECT toDecimal64(1/0, 1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008460d8a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:277: _ZN2DB20convertToDecimalImplINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIlEEEEvQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEET1_RKS8_jRNS9_9FieldTypeE @ 0x0000000032506431 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:322: _ZN2DB16convertToDecimalINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIlEEEEQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEENS9_9FieldTypeERKS8_j @ 0x000000003250c2d5 6. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092461ed 7. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000921d09f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:48:04.410568 [ 4841 ] {b5b24c98-5992-4439-85e4-47567cb1b356} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow. Cannot convert infinity or NaN to decimal: In scope SELECT toDecimal64(1 / 0, 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008460d8a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:277: _ZN2DB20convertToDecimalImplINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIlEEEEvQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEET1_RKS8_jRNS9_9FieldTypeE @ 0x0000000032506431 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:322: _ZN2DB16convertToDecimalINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIlEEEEQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEENS9_9FieldTypeERKS8_j @ 0x000000003250c2d5 6. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092461ed 7. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000921d09f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:48:04.569932 [ 3505 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:04.611358 [ 3508 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:05.036842 [ 3504 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:05.161555 [ 3495 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:05.249597 [ 3498 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:05.324810 [ 3494 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:05.571013 [ 3484 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:05.612467 [ 3486 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:06.037892 [ 3475 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:06.162441 [ 3477 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:06.250625 [ 3480 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:06.250625 [ 4841 ] {52c57e28-1b19-41f9-9e7b-d32b8d74774c} executeQuery: Code: 407. DB::Exception: Decimal convert overflow. Cannot convert infinity or NaN to decimal: In scope SELECT toDecimal128(0 / 0, 2). (DECIMAL_OVERFLOW) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44452) (comment: 00700_decimal_casts_2.sql) (in query: SELECT toDecimal128(0/0, 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008460d8a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:277: _ZN2DB20convertToDecimalImplINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIN4wide7integerILm128EiEEEEEEvQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEET1_RKSB_jRNSC_9FieldTypeE @ 0x0000000032507104 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:322: _ZN2DB16convertToDecimalINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIN4wide7integerILm128EiEEEEEEQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEENSC_9FieldTypeERKSB_j @ 0x000000003250d53c 6. bool DB::callOnIndexAndDataType>>, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000009297a64 7. DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000927189f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:48:06.252403 [ 4841 ] {52c57e28-1b19-41f9-9e7b-d32b8d74774c} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow. Cannot convert infinity or NaN to decimal: In scope SELECT toDecimal128(0 / 0, 2). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008460d8a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:277: _ZN2DB20convertToDecimalImplINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIN4wide7integerILm128EiEEEEEEvQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEET1_RKSB_jRNSC_9FieldTypeE @ 0x0000000032507104 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:322: _ZN2DB16convertToDecimalINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIN4wide7integerILm128EiEEEEEEQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEENSC_9FieldTypeERKSB_j @ 0x000000003250d53c 6. bool DB::callOnIndexAndDataType>>, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000009297a64 7. DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000927189f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:48:06.325991 [ 3472 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:06.450924 [ 3894 ] {a40966b9-73bb-48d2-9aa1-46f15175a649} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max rows: 100.00, current rows: 21.12 thousand. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:43502) (comment: 01131_max_rows_to_sort.sql) (in query: SELECT * FROM system.numbers ORDER BY number;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x00000000323602d7 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:24: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000003235fdb0 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:64: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x00000000323601ec 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000003b8688f0 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acdc84 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae66ecb 9. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 13. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:48:06.453549 [ 3894 ] {a40966b9-73bb-48d2-9aa1-46f15175a649} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max rows: 100.00, current rows: 21.12 thousand. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x00000000323602d7 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:24: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000003235fdb0 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:64: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x00000000323601ec 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000003b8688f0 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acdc84 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae66ecb 9. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 13. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:48:06.572663 [ 3463 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:06.613451 [ 3462 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:06.771272 [ 2903 ] {580349b1-33ca-4bda-8c3d-e6024ea5e7fd} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Milli doesn't match: passed 0, should be 1: In scope SELECT toUnixTimestamp64Milli(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:43518) (comment: 01277_toUnixTimestamp64.sql) (in query: -- Error cases SELECT toUnixTimestamp64Milli();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000b60d377 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000b609265 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60a3eb 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b609cba 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60b9ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334af94d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 30. ? @ 0x00007f100c857ac3 31. ? @ 0x00007f100c8e9850 2025.10.23 23:48:06.773305 [ 2903 ] {580349b1-33ca-4bda-8c3d-e6024ea5e7fd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Milli doesn't match: passed 0, should be 1: In scope SELECT toUnixTimestamp64Milli(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000b60d377 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000b609265 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60a3eb 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b609cba 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60b9ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334af94d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 30. ? @ 0x00007f100c857ac3 31. ? @ 0x00007f100c8e9850 2025.10.23 23:48:06.794541 [ 2903 ] {ce2f5e06-9f98-4b68-ad98-007fa267bd27} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Micro doesn't match: passed 0, should be 1: In scope SELECT toUnixTimestamp64Micro(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:43518) (comment: 01277_toUnixTimestamp64.sql) (in query: SELECT toUnixTimestamp64Micro();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000b60d377 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000b609265 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60a3eb 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b609cba 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60b9ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334af94d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 30. ? @ 0x00007f100c857ac3 31. ? @ 0x00007f100c8e9850 2025.10.23 23:48:06.795998 [ 2903 ] {ce2f5e06-9f98-4b68-ad98-007fa267bd27} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Micro doesn't match: passed 0, should be 1: In scope SELECT toUnixTimestamp64Micro(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000b60d377 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000b609265 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60a3eb 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b609cba 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60b9ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334af94d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 30. ? @ 0x00007f100c857ac3 31. ? @ 0x00007f100c8e9850 2025.10.23 23:48:06.815902 [ 2903 ] {a563007a-6ee8-4ab5-88d4-4775aaf510ea} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Nano doesn't match: passed 0, should be 1: In scope SELECT toUnixTimestamp64Nano(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:43518) (comment: 01277_toUnixTimestamp64.sql) (in query: SELECT toUnixTimestamp64Nano();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000b60d377 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000b609265 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60a3eb 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b609cba 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60b9ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334af94d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 30. ? @ 0x00007f100c857ac3 31. ? @ 0x00007f100c8e9850 2025.10.23 23:48:06.817117 [ 2903 ] {a563007a-6ee8-4ab5-88d4-4775aaf510ea} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Nano doesn't match: passed 0, should be 1: In scope SELECT toUnixTimestamp64Nano(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000b60d377 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000b609265 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60a3eb 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b609cba 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60b9ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334af94d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 30. ? @ 0x00007f100c857ac3 31. ? @ 0x00007f100c8e9850 2025.10.23 23:48:07.039014 [ 3448 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:07.163275 [ 3450 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:07.251599 [ 3449 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:07.327048 [ 3440 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:07.573710 [ 3431 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:07.615322 [ 3533 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:08.115227 [ 4841 ] {5ac10bdd-b19d-49af-addf-cdf6591a7f75} executeQuery: Code: 407. DB::Exception: Decimal convert overflow. Cannot convert infinity or NaN to decimal: In scope SELECT CAST(1 / 0, 'Decimal(9, 0)'). (DECIMAL_OVERFLOW) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44452) (comment: 00700_decimal_casts_2.sql) (in query: SELECT CAST(1/0, 'Decimal(9, 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008460d8a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:277: _ZN2DB20convertToDecimalImplINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIiEEEEvQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEET1_RKS8_jRNS9_9FieldTypeE @ 0x0000000032505b0b 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:322: _ZN2DB16convertToDecimalINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIiEEEEQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEENS9_9FieldTypeERKS8_j @ 0x000000003250b435 6. _ZN2DBL22callOnIndexAndDataTypeINS_15DataTypeDecimalINS_7DecimalIiEEEEZZNKS_12_GLOBAL__N_112FunctionCast20createDecimalWrapperIS4_Q17IsDataTypeDecimalIT_EEENSt3__18functionIFN3COWINS_7IColumnEE13immutable_ptrISC_EERNS9_6vectorINS_21ColumnWithTypeAndNameENS9_9allocatorISH_EEEERKNS9_10shared_ptrIKNS_9IDataTypeEEEPKNS_14ColumnNullableEmEEESR_PKS8_bENKUlSL_SR_SU_mE_clESL_SR_SU_mEUlRSX_E_JEEEbNS_9TypeIndexEOT0_DpOT1_ @ 0x0000000008c64b0e 7. _ZNSt3__110__function16__policy_invokerIFN3COWIN2DB7IColumnEE13immutable_ptrIS4_EERNS_6vectorINS3_21ColumnWithTypeAndNameENS_9allocatorIS9_EEEERKNS_10shared_ptrIKNS3_9IDataTypeEEEPKNS3_14ColumnNullableEmEE11__call_implINS0_20__default_alloc_funcIZNKS3_12_GLOBAL__N_112FunctionCast20createDecimalWrapperINS3_15DataTypeDecimalINS3_7DecimalIiEEEEQ17IsDataTypeDecimalIT_EEENS_8functionISN_EESJ_PKSY_bEUlSD_SJ_SM_mE_SN_EEEES7_PKNS0_16__policy_storageESD_SJ_SM_m @ 0x0000000008c3fefd 8. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086d2b34 9. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008425b22 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601e5f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:48:08.115777 [ 3428 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:08.117133 [ 4841 ] {5ac10bdd-b19d-49af-addf-cdf6591a7f75} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow. Cannot convert infinity or NaN to decimal: In scope SELECT CAST(1 / 0, 'Decimal(9, 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008460d8a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:277: _ZN2DB20convertToDecimalImplINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIiEEEEvQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEET1_RKS8_jRNS9_9FieldTypeE @ 0x0000000032505b0b 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:322: _ZN2DB16convertToDecimalINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIiEEEEQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEENS9_9FieldTypeERKS8_j @ 0x000000003250b435 6. _ZN2DBL22callOnIndexAndDataTypeINS_15DataTypeDecimalINS_7DecimalIiEEEEZZNKS_12_GLOBAL__N_112FunctionCast20createDecimalWrapperIS4_Q17IsDataTypeDecimalIT_EEENSt3__18functionIFN3COWINS_7IColumnEE13immutable_ptrISC_EERNS9_6vectorINS_21ColumnWithTypeAndNameENS9_9allocatorISH_EEEERKNS9_10shared_ptrIKNS_9IDataTypeEEEPKNS_14ColumnNullableEmEEESR_PKS8_bENKUlSL_SR_SU_mE_clESL_SR_SU_mEUlRSX_E_JEEEbNS_9TypeIndexEOT0_DpOT1_ @ 0x0000000008c64b0e 7. _ZNSt3__110__function16__policy_invokerIFN3COWIN2DB7IColumnEE13immutable_ptrIS4_EERNS_6vectorINS3_21ColumnWithTypeAndNameENS_9allocatorIS9_EEEERKNS_10shared_ptrIKNS3_9IDataTypeEEEPKNS3_14ColumnNullableEmEE11__call_implINS0_20__default_alloc_funcIZNKS3_12_GLOBAL__N_112FunctionCast20createDecimalWrapperINS3_15DataTypeDecimalINS3_7DecimalIiEEEEQ17IsDataTypeDecimalIT_EEENS_8functionISN_EESJ_PKSY_bEUlSD_SJ_SM_mE_SN_EEEES7_PKNS0_16__policy_storageESD_SJ_SM_m @ 0x0000000008c3fefd 8. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086d2b34 9. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008425b22 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601e5f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:48:08.164385 [ 3422 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:08.252855 [ 3416 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:08.328358 [ 3415 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:08.574941 [ 3412 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:08.617128 [ 3405 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:08.875634 [ 2903 ] {f9527b9c-63e8-45c0-aad5-042fd1396514} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'toUnixTimestamp64Milli'. Expected: DateTime64, got: String: In scope SELECT toUnixTimestamp64Milli('abc'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:43518) (comment: 01277_toUnixTimestamp64.sql) (in query: SELECT toUnixTimestamp64Milli('abc');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084076a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000084008e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fefba 6. DB::FunctionToUnixTimestamp64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c76742b 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083d29bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60aa37 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b609cba 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60b9ac 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334af94d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 2025.10.23 23:48:08.880588 [ 2903 ] {f9527b9c-63e8-45c0-aad5-042fd1396514} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'toUnixTimestamp64Milli'. Expected: DateTime64, got: String: In scope SELECT toUnixTimestamp64Milli('abc'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084076a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000084008e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fefba 6. DB::FunctionToUnixTimestamp64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c76742b 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083d29bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60aa37 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b609cba 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60b9ac 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334af94d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 2025.10.23 23:48:08.911532 [ 2903 ] {6eda6fd9-5d21-429e-8c33-3842993bdbaa} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'toUnixTimestamp64Micro'. Expected: DateTime64, got: String: In scope SELECT toUnixTimestamp64Micro('abc'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:43518) (comment: 01277_toUnixTimestamp64.sql) (in query: SELECT toUnixTimestamp64Micro('abc');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084076a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000084008e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fefba 6. DB::FunctionToUnixTimestamp64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c76742b 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083d29bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60aa37 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b609cba 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60b9ac 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334af94d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 2025.10.23 23:48:08.913963 [ 2903 ] {6eda6fd9-5d21-429e-8c33-3842993bdbaa} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'toUnixTimestamp64Micro'. Expected: DateTime64, got: String: In scope SELECT toUnixTimestamp64Micro('abc'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084076a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000084008e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fefba 6. DB::FunctionToUnixTimestamp64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c76742b 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083d29bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60aa37 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b609cba 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60b9ac 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334af94d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 2025.10.23 23:48:09.038024 [ 2903 ] {b81f03f7-7cbd-43fc-aedf-c49cbb128a96} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'toUnixTimestamp64Nano'. Expected: DateTime64, got: String: In scope SELECT toUnixTimestamp64Nano('abc'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:43518) (comment: 01277_toUnixTimestamp64.sql) (in query: SELECT toUnixTimestamp64Nano('abc');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084076a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000084008e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fefba 6. DB::FunctionToUnixTimestamp64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c76742b 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083d29bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60aa37 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b609cba 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60b9ac 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334af94d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 2025.10.23 23:48:09.040557 [ 2903 ] {b81f03f7-7cbd-43fc-aedf-c49cbb128a96} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'toUnixTimestamp64Nano'. Expected: DateTime64, got: String: In scope SELECT toUnixTimestamp64Nano('abc'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084076a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000084008e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fefba 6. DB::FunctionToUnixTimestamp64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c76742b 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083d29bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60aa37 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b609cba 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60b9ac 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334af94d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 2025.10.23 23:48:09.117305 [ 3389 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:09.165556 [ 3394 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:09.166915 [ 2903 ] {b6a9340b-f8d9-473b-9c42-a0675cc00a00} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Milli doesn't match: passed 2, should be 1: In scope SELECT toUnixTimestamp64Milli('abc', 123). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:43518) (comment: 01277_toUnixTimestamp64.sql) (in query: SELECT toUnixTimestamp64Milli('abc', 123);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000b60d377 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000b609265 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60a3eb 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b609cba 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60b9ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334af94d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 30. ? @ 0x00007f100c857ac3 31. ? @ 0x00007f100c8e9850 2025.10.23 23:48:09.169056 [ 2903 ] {b6a9340b-f8d9-473b-9c42-a0675cc00a00} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Milli doesn't match: passed 2, should be 1: In scope SELECT toUnixTimestamp64Milli('abc', 123). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000b60d377 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000b609265 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60a3eb 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b609cba 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60b9ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334af94d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 30. ? @ 0x00007f100c857ac3 31. ? @ 0x00007f100c8e9850 2025.10.23 23:48:09.200197 [ 2903 ] {9791f783-f96d-4829-ad47-4f4659ccc844} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Micro doesn't match: passed 2, should be 1: In scope SELECT toUnixTimestamp64Micro('abc', 123). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:43518) (comment: 01277_toUnixTimestamp64.sql) (in query: SELECT toUnixTimestamp64Micro('abc', 123);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000b60d377 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000b609265 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60a3eb 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b609cba 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60b9ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334af94d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 30. ? @ 0x00007f100c857ac3 31. ? @ 0x00007f100c8e9850 2025.10.23 23:48:09.202446 [ 2903 ] {9791f783-f96d-4829-ad47-4f4659ccc844} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Micro doesn't match: passed 2, should be 1: In scope SELECT toUnixTimestamp64Micro('abc', 123). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000b60d377 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000b609265 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60a3eb 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b609cba 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60b9ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334af94d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 30. ? @ 0x00007f100c857ac3 31. ? @ 0x00007f100c8e9850 2025.10.23 23:48:09.235626 [ 2903 ] {37e172f5-1786-4f60-8db9-d0c37fdea2ac} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Nano doesn't match: passed 2, should be 1: In scope SELECT toUnixTimestamp64Nano('abc', 123). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:43518) (comment: 01277_toUnixTimestamp64.sql) (in query: SELECT toUnixTimestamp64Nano('abc', 123);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000b60d377 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000b609265 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60a3eb 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b609cba 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60b9ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334af94d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 30. ? @ 0x00007f100c857ac3 31. ? @ 0x00007f100c8e9850 2025.10.23 23:48:09.237764 [ 2903 ] {37e172f5-1786-4f60-8db9-d0c37fdea2ac} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Nano doesn't match: passed 2, should be 1: In scope SELECT toUnixTimestamp64Nano('abc', 123). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000b60d377 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000b609265 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60a3eb 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b609cba 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60b9ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334af94d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 30. ? @ 0x00007f100c857ac3 31. ? @ 0x00007f100c8e9850 2025.10.23 23:48:09.254146 [ 3381 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:09.329556 [ 3378 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:09.576460 [ 3367 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:09.618433 [ 3368 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:10.118697 [ 3360 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:10.166748 [ 3351 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:10.255845 [ 3358 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:10.329508 [ 3894 ] {0f5a5055-5c22-4aed-8dd2-08eb570968b2} executeQuery: Code: 69. DB::Exception: The number of shift positions needs to be a non-negative value: In scope SELECT bitShiftRight(1, -1). (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:43524) (comment: 03198_bit_shift_throws_error_for_out_of_bounds.sql) (in query: SELECT bitShiftRight(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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. _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_117BitShiftRightImplENS12_17NameBitShiftRightELb1ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clIS2_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x000000000d466b72 5. 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&&) @ 0x000000000d43bac2 6. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d42c43b 7. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d4286c8 8. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d424d7c 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 2025.10.23 23:48:10.330715 [ 3363 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:10.331980 [ 3894 ] {0f5a5055-5c22-4aed-8dd2-08eb570968b2} TCPHandler: Code: 69. DB::Exception: The number of shift positions needs to be a non-negative value: In scope SELECT bitShiftRight(1, -1). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. _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_117BitShiftRightImplENS12_17NameBitShiftRightELb1ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clIS2_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x000000000d466b72 5. 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&&) @ 0x000000000d43bac2 6. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d42c43b 7. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d4286c8 8. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d424d7c 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 2025.10.23 23:48:10.577500 [ 3373 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:10.619778 [ 3340 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:11.010893 [ 4841 ] {0ce3ef06-40ce-4979-887a-85b786fc58a5} executeQuery: Code: 407. DB::Exception: Decimal convert overflow. Cannot convert infinity or NaN to decimal: In scope SELECT CAST(1 / 0, 'Decimal(18, 1)'). (DECIMAL_OVERFLOW) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44452) (comment: 00700_decimal_casts_2.sql) (in query: SELECT CAST(1/0, 'Decimal(18, 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008460d8a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:277: _ZN2DB20convertToDecimalImplINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIlEEEEvQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEET1_RKS8_jRNS9_9FieldTypeE @ 0x0000000032506431 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:322: _ZN2DB16convertToDecimalINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIlEEEEQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEENS9_9FieldTypeERKS8_j @ 0x000000003250c2d5 6. _ZN2DBL22callOnIndexAndDataTypeINS_15DataTypeDecimalINS_7DecimalIlEEEEZZNKS_12_GLOBAL__N_112FunctionCast20createDecimalWrapperIS4_Q17IsDataTypeDecimalIT_EEENSt3__18functionIFN3COWINS_7IColumnEE13immutable_ptrISC_EERNS9_6vectorINS_21ColumnWithTypeAndNameENS9_9allocatorISH_EEEERKNS9_10shared_ptrIKNS_9IDataTypeEEEPKNS_14ColumnNullableEmEEESR_PKS8_bENKUlSL_SR_SU_mE_clESL_SR_SU_mEUlRSX_E_JEEEbNS_9TypeIndexEOT0_DpOT1_ @ 0x0000000008caebcd 7. _ZNSt3__110__function16__policy_invokerIFN3COWIN2DB7IColumnEE13immutable_ptrIS4_EERNS_6vectorINS3_21ColumnWithTypeAndNameENS_9allocatorIS9_EEEERKNS_10shared_ptrIKNS3_9IDataTypeEEEPKNS3_14ColumnNullableEmEE11__call_implINS0_20__default_alloc_funcIZNKS3_12_GLOBAL__N_112FunctionCast20createDecimalWrapperINS3_15DataTypeDecimalINS3_7DecimalIlEEEEQ17IsDataTypeDecimalIT_EEENS_8functionISN_EESJ_PKSY_bEUlSD_SJ_SM_mE_SN_EEEES7_PKNS0_16__policy_storageESD_SJ_SM_m @ 0x0000000008c86d7d 8. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086d2b34 9. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008425b22 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601e5f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:48:11.013485 [ 4841 ] {0ce3ef06-40ce-4979-887a-85b786fc58a5} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow. Cannot convert infinity or NaN to decimal: In scope SELECT CAST(1 / 0, 'Decimal(18, 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008460d8a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:277: _ZN2DB20convertToDecimalImplINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIlEEEEvQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEET1_RKS8_jRNS9_9FieldTypeE @ 0x0000000032506431 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:322: _ZN2DB16convertToDecimalINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIlEEEEQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEENS9_9FieldTypeERKS8_j @ 0x000000003250c2d5 6. _ZN2DBL22callOnIndexAndDataTypeINS_15DataTypeDecimalINS_7DecimalIlEEEEZZNKS_12_GLOBAL__N_112FunctionCast20createDecimalWrapperIS4_Q17IsDataTypeDecimalIT_EEENSt3__18functionIFN3COWINS_7IColumnEE13immutable_ptrISC_EERNS9_6vectorINS_21ColumnWithTypeAndNameENS9_9allocatorISH_EEEERKNS9_10shared_ptrIKNS_9IDataTypeEEEPKNS_14ColumnNullableEmEEESR_PKS8_bENKUlSL_SR_SU_mE_clESL_SR_SU_mEUlRSX_E_JEEEbNS_9TypeIndexEOT0_DpOT1_ @ 0x0000000008caebcd 7. _ZNSt3__110__function16__policy_invokerIFN3COWIN2DB7IColumnEE13immutable_ptrIS4_EERNS_6vectorINS3_21ColumnWithTypeAndNameENS_9allocatorIS9_EEEERKNS_10shared_ptrIKNS3_9IDataTypeEEEPKNS3_14ColumnNullableEmEE11__call_implINS0_20__default_alloc_funcIZNKS3_12_GLOBAL__N_112FunctionCast20createDecimalWrapperINS3_15DataTypeDecimalINS3_7DecimalIlEEEEQ17IsDataTypeDecimalIT_EEENS_8functionISN_EESJ_PKSY_bEUlSD_SJ_SM_mE_SN_EEEES7_PKNS0_16__policy_storageESD_SJ_SM_m @ 0x0000000008c86d7d 8. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086d2b34 9. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008425b22 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601e5f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:48:11.120642 [ 3336 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:11.167823 [ 3365 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:11.257137 [ 3372 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:11.332074 [ 3330 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:11.578394 [ 3341 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:11.621121 [ 3331 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:12.121786 [ 3317 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:12.168614 [ 3304 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:12.258016 [ 3321 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:12.333045 [ 3306 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:12.477464 [ 2903 ] {9bf834db-49ef-4f5b-bc18-29c2caf144ad} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:43550) (comment: 02918_fuzzjson_table_function.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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000003159b57b 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337550f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e79fb4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:48:12.479616 [ 2903 ] {9bf834db-49ef-4f5b-bc18-29c2caf144ad} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000003159b57b 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337550f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e79fb4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:48:12.579499 [ 3308 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:12.622501 [ 3303 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:12.805195 [ 3894 ] {2d09f713-9d19-4cfe-9f86-2ed9f08ddaa8} executeQuery: Code: 69. DB::Exception: The number of shift positions needs to be a non-negative value: In scope SELECT bitShiftRight('hola', -1). (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:43524) (comment: 03198_bit_shift_throws_error_for_out_of_bounds.sql) (in query: SELECT bitShiftRight('hola', -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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. void DB::impl_::StringIntegerOperationImpl<_BitInt(8), DB::(anonymous namespace)::BitShiftRightImpl>::processString<(DB::impl_::OpCase)0>(char8_t const*, unsigned long const*, DB::(anonymous namespace) const*, DB::PODArray, 63ul, 64ul>&, Allocator, 63ul, 64ul>, 63ul, 64ul>&, unsigned long) @ 0x000000000d41b317 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_117BitShiftRightImplENS12_17NameBitShiftRightELb1ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clISY_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x000000000d5e1ec8 6. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d443941 7. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d42c43b 8. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d4286c8 9. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d424d7c 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 11. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:48:12.806934 [ 3894 ] {2d09f713-9d19-4cfe-9f86-2ed9f08ddaa8} TCPHandler: Code: 69. DB::Exception: The number of shift positions needs to be a non-negative value: In scope SELECT bitShiftRight('hola', -1). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. void DB::impl_::StringIntegerOperationImpl<_BitInt(8), DB::(anonymous namespace)::BitShiftRightImpl>::processString<(DB::impl_::OpCase)0>(char8_t const*, unsigned long const*, DB::(anonymous namespace) const*, DB::PODArray, 63ul, 64ul>&, Allocator, 63ul, 64ul>, 63ul, 64ul>&, unsigned long) @ 0x000000000d41b317 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_117BitShiftRightImplENS12_17NameBitShiftRightELb1ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clISY_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x000000000d5e1ec8 6. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d443941 7. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d42c43b 8. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d4286c8 9. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d424d7c 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 11. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:48:13.123016 [ 3312 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:13.169840 [ 3289 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:13.259128 [ 3285 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:13.334338 [ 3287 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:13.620031 [ 3281 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:13.624100 [ 3272 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:14.193735 [ 3274 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:14.193818 [ 3257 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:14.245000 [ 4841 ] {612c44f9-6d33-48f7-8b60-eec4b1c9d6fa} executeQuery: Code: 407. DB::Exception: Decimal convert overflow. Cannot convert infinity or NaN to decimal: In scope SELECT CAST(1 / 0, 'Decimal(38, 2)'). (DECIMAL_OVERFLOW) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44452) (comment: 00700_decimal_casts_2.sql) (in query: SELECT CAST(1/0, 'Decimal(38, 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008460d8a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:277: _ZN2DB20convertToDecimalImplINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIN4wide7integerILm128EiEEEEEEvQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEET1_RKSB_jRNSC_9FieldTypeE @ 0x0000000032507104 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:322: _ZN2DB16convertToDecimalINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIN4wide7integerILm128EiEEEEEEQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEENSC_9FieldTypeERKSB_j @ 0x000000003250d53c 6. _ZN2DBL22callOnIndexAndDataTypeINS_15DataTypeDecimalINS_7DecimalIN4wide7integerILm128EiEEEEEEZZNKS_12_GLOBAL__N_112FunctionCast20createDecimalWrapperIS7_Q17IsDataTypeDecimalIT_EEENSt3__18functionIFN3COWINS_7IColumnEE13immutable_ptrISF_EERNSC_6vectorINS_21ColumnWithTypeAndNameENSC_9allocatorISK_EEEERKNSC_10shared_ptrIKNS_9IDataTypeEEEPKNS_14ColumnNullableEmEEESU_PKSB_bENKUlSO_SU_SX_mE_clESO_SU_SX_mEUlRS10_E_JEEEbNS_9TypeIndexEOT0_DpOT1_ @ 0x0000000008cf286c 7. _ZNSt3__110__function16__policy_invokerIFN3COWIN2DB7IColumnEE13immutable_ptrIS4_EERNS_6vectorINS3_21ColumnWithTypeAndNameENS_9allocatorIS9_EEEERKNS_10shared_ptrIKNS3_9IDataTypeEEEPKNS3_14ColumnNullableEmEE11__call_implINS0_20__default_alloc_funcIZNKS3_12_GLOBAL__N_112FunctionCast20createDecimalWrapperINS3_15DataTypeDecimalINS3_7DecimalIN4wide7integerILm128EiEEEEEEQ17IsDataTypeDecimalIT_EEENS_8functionISN_EESJ_PKS11_bEUlSD_SJ_SM_mE_SN_EEEES7_PKNS0_16__policy_storageESD_SJ_SM_m @ 0x0000000008ccd39d 8. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086d2b34 9. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008425b22 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601e5f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:48:14.246652 [ 4841 ] {612c44f9-6d33-48f7-8b60-eec4b1c9d6fa} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow. Cannot convert infinity or NaN to decimal: In scope SELECT CAST(1 / 0, 'Decimal(38, 2)'). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008460d8a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:277: _ZN2DB20convertToDecimalImplINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIN4wide7integerILm128EiEEEEEEvQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEET1_RKSB_jRNSC_9FieldTypeE @ 0x0000000032507104 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:322: _ZN2DB16convertToDecimalINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIN4wide7integerILm128EiEEEEEEQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEENSC_9FieldTypeERKSB_j @ 0x000000003250d53c 6. _ZN2DBL22callOnIndexAndDataTypeINS_15DataTypeDecimalINS_7DecimalIN4wide7integerILm128EiEEEEEEZZNKS_12_GLOBAL__N_112FunctionCast20createDecimalWrapperIS7_Q17IsDataTypeDecimalIT_EEENSt3__18functionIFN3COWINS_7IColumnEE13immutable_ptrISF_EERNSC_6vectorINS_21ColumnWithTypeAndNameENSC_9allocatorISK_EEEERKNSC_10shared_ptrIKNS_9IDataTypeEEEPKNS_14ColumnNullableEmEEESU_PKSB_bENKUlSO_SU_SX_mE_clESO_SU_SX_mEUlRS10_E_JEEEbNS_9TypeIndexEOT0_DpOT1_ @ 0x0000000008cf286c 7. _ZNSt3__110__function16__policy_invokerIFN3COWIN2DB7IColumnEE13immutable_ptrIS4_EERNS_6vectorINS3_21ColumnWithTypeAndNameENS_9allocatorIS9_EEEERKNS_10shared_ptrIKNS3_9IDataTypeEEEPKNS3_14ColumnNullableEmEE11__call_implINS0_20__default_alloc_funcIZNKS3_12_GLOBAL__N_112FunctionCast20createDecimalWrapperINS3_15DataTypeDecimalINS3_7DecimalIN4wide7integerILm128EiEEEEEEQ17IsDataTypeDecimalIT_EEENS_8functionISN_EESJ_PKS11_bEUlSD_SJ_SM_mE_SN_EEEES7_PKNS0_16__policy_storageESD_SJ_SM_m @ 0x0000000008ccd39d 8. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086d2b34 9. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008425b22 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601e5f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:48:14.260217 [ 3264 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:14.265756 [ 4841 ] {2541a0c6-9eee-4e23-9d17-d267e9733383} executeQuery: Code: 407. DB::Exception: Decimal convert overflow. Cannot convert infinity or NaN to decimal: In scope SELECT CAST(0 / 0, 'Decimal(9, 3)'). (DECIMAL_OVERFLOW) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44452) (comment: 00700_decimal_casts_2.sql) (in query: SELECT CAST(0/0, 'Decimal(9, 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008460d8a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:277: _ZN2DB20convertToDecimalImplINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIiEEEEvQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEET1_RKS8_jRNS9_9FieldTypeE @ 0x0000000032505b0b 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:322: _ZN2DB16convertToDecimalINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIiEEEEQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEENS9_9FieldTypeERKS8_j @ 0x000000003250b435 6. _ZN2DBL22callOnIndexAndDataTypeINS_15DataTypeDecimalINS_7DecimalIiEEEEZZNKS_12_GLOBAL__N_112FunctionCast20createDecimalWrapperIS4_Q17IsDataTypeDecimalIT_EEENSt3__18functionIFN3COWINS_7IColumnEE13immutable_ptrISC_EERNS9_6vectorINS_21ColumnWithTypeAndNameENS9_9allocatorISH_EEEERKNS9_10shared_ptrIKNS_9IDataTypeEEEPKNS_14ColumnNullableEmEEESR_PKS8_bENKUlSL_SR_SU_mE_clESL_SR_SU_mEUlRSX_E_JEEEbNS_9TypeIndexEOT0_DpOT1_ @ 0x0000000008c64b0e 7. _ZNSt3__110__function16__policy_invokerIFN3COWIN2DB7IColumnEE13immutable_ptrIS4_EERNS_6vectorINS3_21ColumnWithTypeAndNameENS_9allocatorIS9_EEEERKNS_10shared_ptrIKNS3_9IDataTypeEEEPKNS3_14ColumnNullableEmEE11__call_implINS0_20__default_alloc_funcIZNKS3_12_GLOBAL__N_112FunctionCast20createDecimalWrapperINS3_15DataTypeDecimalINS3_7DecimalIiEEEEQ17IsDataTypeDecimalIT_EEENS_8functionISN_EESJ_PKSY_bEUlSD_SJ_SM_mE_SN_EEEES7_PKNS0_16__policy_storageESD_SJ_SM_m @ 0x0000000008c3fefd 8. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086d2b34 9. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008425b22 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601e5f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:48:14.267147 [ 4841 ] {2541a0c6-9eee-4e23-9d17-d267e9733383} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow. Cannot convert infinity or NaN to decimal: In scope SELECT CAST(0 / 0, 'Decimal(9, 3)'). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008460d8a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:277: _ZN2DB20convertToDecimalImplINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIiEEEEvQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEET1_RKS8_jRNS9_9FieldTypeE @ 0x0000000032505b0b 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:322: _ZN2DB16convertToDecimalINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIiEEEEQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEENS9_9FieldTypeERKS8_j @ 0x000000003250b435 6. _ZN2DBL22callOnIndexAndDataTypeINS_15DataTypeDecimalINS_7DecimalIiEEEEZZNKS_12_GLOBAL__N_112FunctionCast20createDecimalWrapperIS4_Q17IsDataTypeDecimalIT_EEENSt3__18functionIFN3COWINS_7IColumnEE13immutable_ptrISC_EERNS9_6vectorINS_21ColumnWithTypeAndNameENS9_9allocatorISH_EEEERKNS9_10shared_ptrIKNS_9IDataTypeEEEPKNS_14ColumnNullableEmEEESR_PKS8_bENKUlSL_SR_SU_mE_clESL_SR_SU_mEUlRSX_E_JEEEbNS_9TypeIndexEOT0_DpOT1_ @ 0x0000000008c64b0e 7. _ZNSt3__110__function16__policy_invokerIFN3COWIN2DB7IColumnEE13immutable_ptrIS4_EERNS_6vectorINS3_21ColumnWithTypeAndNameENS_9allocatorIS9_EEEERKNS_10shared_ptrIKNS3_9IDataTypeEEEPKNS3_14ColumnNullableEmEE11__call_implINS0_20__default_alloc_funcIZNKS3_12_GLOBAL__N_112FunctionCast20createDecimalWrapperINS3_15DataTypeDecimalINS3_7DecimalIiEEEEQ17IsDataTypeDecimalIT_EEENS_8functionISN_EESJ_PKSY_bEUlSD_SJ_SM_mE_SN_EEEES7_PKNS0_16__policy_storageESD_SJ_SM_m @ 0x0000000008c3fefd 8. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086d2b34 9. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008425b22 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601e5f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:48:14.313384 [ 4841 ] {7355a3b2-89f8-459b-8131-449ffb6b2929} executeQuery: Code: 407. DB::Exception: Decimal convert overflow. Cannot convert infinity or NaN to decimal: In scope SELECT CAST(0 / 0, 'Decimal(18, 4)'). (DECIMAL_OVERFLOW) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44452) (comment: 00700_decimal_casts_2.sql) (in query: SELECT CAST(0/0, 'Decimal(18, 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008460d8a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:277: _ZN2DB20convertToDecimalImplINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIlEEEEvQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEET1_RKS8_jRNS9_9FieldTypeE @ 0x0000000032506431 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:322: _ZN2DB16convertToDecimalINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIlEEEEQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEENS9_9FieldTypeERKS8_j @ 0x000000003250c2d5 6. _ZN2DBL22callOnIndexAndDataTypeINS_15DataTypeDecimalINS_7DecimalIlEEEEZZNKS_12_GLOBAL__N_112FunctionCast20createDecimalWrapperIS4_Q17IsDataTypeDecimalIT_EEENSt3__18functionIFN3COWINS_7IColumnEE13immutable_ptrISC_EERNS9_6vectorINS_21ColumnWithTypeAndNameENS9_9allocatorISH_EEEERKNS9_10shared_ptrIKNS_9IDataTypeEEEPKNS_14ColumnNullableEmEEESR_PKS8_bENKUlSL_SR_SU_mE_clESL_SR_SU_mEUlRSX_E_JEEEbNS_9TypeIndexEOT0_DpOT1_ @ 0x0000000008caebcd 7. _ZNSt3__110__function16__policy_invokerIFN3COWIN2DB7IColumnEE13immutable_ptrIS4_EERNS_6vectorINS3_21ColumnWithTypeAndNameENS_9allocatorIS9_EEEERKNS_10shared_ptrIKNS3_9IDataTypeEEEPKNS3_14ColumnNullableEmEE11__call_implINS0_20__default_alloc_funcIZNKS3_12_GLOBAL__N_112FunctionCast20createDecimalWrapperINS3_15DataTypeDecimalINS3_7DecimalIlEEEEQ17IsDataTypeDecimalIT_EEENS_8functionISN_EESJ_PKSY_bEUlSD_SJ_SM_mE_SN_EEEES7_PKNS0_16__policy_storageESD_SJ_SM_m @ 0x0000000008c86d7d 8. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086d2b34 9. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008425b22 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601e5f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:48:14.315251 [ 4841 ] {7355a3b2-89f8-459b-8131-449ffb6b2929} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow. Cannot convert infinity or NaN to decimal: In scope SELECT CAST(0 / 0, 'Decimal(18, 4)'). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008460d8a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:277: _ZN2DB20convertToDecimalImplINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIlEEEEvQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEET1_RKS8_jRNS9_9FieldTypeE @ 0x0000000032506431 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:322: _ZN2DB16convertToDecimalINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIlEEEEQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEENS9_9FieldTypeERKS8_j @ 0x000000003250c2d5 6. _ZN2DBL22callOnIndexAndDataTypeINS_15DataTypeDecimalINS_7DecimalIlEEEEZZNKS_12_GLOBAL__N_112FunctionCast20createDecimalWrapperIS4_Q17IsDataTypeDecimalIT_EEENSt3__18functionIFN3COWINS_7IColumnEE13immutable_ptrISC_EERNS9_6vectorINS_21ColumnWithTypeAndNameENS9_9allocatorISH_EEEERKNS9_10shared_ptrIKNS_9IDataTypeEEEPKNS_14ColumnNullableEmEEESR_PKS8_bENKUlSL_SR_SU_mE_clESL_SR_SU_mEUlRSX_E_JEEEbNS_9TypeIndexEOT0_DpOT1_ @ 0x0000000008caebcd 7. _ZNSt3__110__function16__policy_invokerIFN3COWIN2DB7IColumnEE13immutable_ptrIS4_EERNS_6vectorINS3_21ColumnWithTypeAndNameENS_9allocatorIS9_EEEERKNS_10shared_ptrIKNS3_9IDataTypeEEEPKNS3_14ColumnNullableEmEE11__call_implINS0_20__default_alloc_funcIZNKS3_12_GLOBAL__N_112FunctionCast20createDecimalWrapperINS3_15DataTypeDecimalINS3_7DecimalIlEEEEQ17IsDataTypeDecimalIT_EEENS_8functionISN_EESJ_PKSY_bEUlSD_SJ_SM_mE_SN_EEEES7_PKNS0_16__policy_storageESD_SJ_SM_m @ 0x0000000008c86d7d 8. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086d2b34 9. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008425b22 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601e5f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:48:14.335540 [ 3263 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:14.335605 [ 4841 ] {3587473a-b9dd-4672-b91b-555bb5195445} executeQuery: Code: 407. DB::Exception: Decimal convert overflow. Cannot convert infinity or NaN to decimal: In scope SELECT CAST(0 / 0, 'Decimal(38, 5)'). (DECIMAL_OVERFLOW) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44452) (comment: 00700_decimal_casts_2.sql) (in query: SELECT CAST(0/0, 'Decimal(38, 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008460d8a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:277: _ZN2DB20convertToDecimalImplINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIN4wide7integerILm128EiEEEEEEvQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEET1_RKSB_jRNSC_9FieldTypeE @ 0x0000000032507104 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:322: _ZN2DB16convertToDecimalINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIN4wide7integerILm128EiEEEEEEQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEENSC_9FieldTypeERKSB_j @ 0x000000003250d53c 6. _ZN2DBL22callOnIndexAndDataTypeINS_15DataTypeDecimalINS_7DecimalIN4wide7integerILm128EiEEEEEEZZNKS_12_GLOBAL__N_112FunctionCast20createDecimalWrapperIS7_Q17IsDataTypeDecimalIT_EEENSt3__18functionIFN3COWINS_7IColumnEE13immutable_ptrISF_EERNSC_6vectorINS_21ColumnWithTypeAndNameENSC_9allocatorISK_EEEERKNSC_10shared_ptrIKNS_9IDataTypeEEEPKNS_14ColumnNullableEmEEESU_PKSB_bENKUlSO_SU_SX_mE_clESO_SU_SX_mEUlRS10_E_JEEEbNS_9TypeIndexEOT0_DpOT1_ @ 0x0000000008cf286c 7. _ZNSt3__110__function16__policy_invokerIFN3COWIN2DB7IColumnEE13immutable_ptrIS4_EERNS_6vectorINS3_21ColumnWithTypeAndNameENS_9allocatorIS9_EEEERKNS_10shared_ptrIKNS3_9IDataTypeEEEPKNS3_14ColumnNullableEmEE11__call_implINS0_20__default_alloc_funcIZNKS3_12_GLOBAL__N_112FunctionCast20createDecimalWrapperINS3_15DataTypeDecimalINS3_7DecimalIN4wide7integerILm128EiEEEEEEQ17IsDataTypeDecimalIT_EEENS_8functionISN_EESJ_PKS11_bEUlSD_SJ_SM_mE_SN_EEEES7_PKNS0_16__policy_storageESD_SJ_SM_m @ 0x0000000008ccd39d 8. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086d2b34 9. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008425b22 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601e5f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:48:14.337071 [ 4841 ] {3587473a-b9dd-4672-b91b-555bb5195445} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow. Cannot convert infinity or NaN to decimal: In scope SELECT CAST(0 / 0, 'Decimal(38, 5)'). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008460d8a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:277: _ZN2DB20convertToDecimalImplINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIN4wide7integerILm128EiEEEEEEvQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEET1_RKSB_jRNSC_9FieldTypeE @ 0x0000000032507104 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:322: _ZN2DB16convertToDecimalINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIN4wide7integerILm128EiEEEEEEQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEENSC_9FieldTypeERKSB_j @ 0x000000003250d53c 6. _ZN2DBL22callOnIndexAndDataTypeINS_15DataTypeDecimalINS_7DecimalIN4wide7integerILm128EiEEEEEEZZNKS_12_GLOBAL__N_112FunctionCast20createDecimalWrapperIS7_Q17IsDataTypeDecimalIT_EEENSt3__18functionIFN3COWINS_7IColumnEE13immutable_ptrISF_EERNSC_6vectorINS_21ColumnWithTypeAndNameENSC_9allocatorISK_EEEERKNSC_10shared_ptrIKNS_9IDataTypeEEEPKNS_14ColumnNullableEmEEESU_PKSB_bENKUlSO_SU_SX_mE_clESO_SU_SX_mEUlRS10_E_JEEEbNS_9TypeIndexEOT0_DpOT1_ @ 0x0000000008cf286c 7. _ZNSt3__110__function16__policy_invokerIFN3COWIN2DB7IColumnEE13immutable_ptrIS4_EERNS_6vectorINS3_21ColumnWithTypeAndNameENS_9allocatorIS9_EEEERKNS_10shared_ptrIKNS3_9IDataTypeEEEPKNS3_14ColumnNullableEmEE11__call_implINS0_20__default_alloc_funcIZNKS3_12_GLOBAL__N_112FunctionCast20createDecimalWrapperINS3_15DataTypeDecimalINS3_7DecimalIN4wide7integerILm128EiEEEEEEQ17IsDataTypeDecimalIT_EEENS_8functionISN_EESJ_PKS11_bEUlSD_SJ_SM_mE_SN_EEEES7_PKNS0_16__policy_storageESD_SJ_SM_m @ 0x0000000008ccd39d 8. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086d2b34 9. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008425b22 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601e5f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:48:14.621109 [ 3271 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:14.625124 [ 3251 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:15.116416 [ 3894 ] {aeafbb58-f3cf-47bd-b6e5-65ffc857b5e3} executeQuery: Code: 69. DB::Exception: The number of shift positions needs to be a non-negative value: In scope SELECT bitShiftRight(toFixedString('hola', 8), -1). (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:43524) (comment: 03198_bit_shift_throws_error_for_out_of_bounds.sql) (in query: SELECT bitShiftRight(toFixedString('hola', 8), -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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. void DB::impl_::StringIntegerOperationImpl<_BitInt(8), DB::(anonymous namespace)::BitShiftRightImpl>::processFixedString<(DB::impl_::OpCase)0>(char8_t const*, unsigned long, DB::(anonymous namespace) const*, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x000000000d40a277 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_117BitShiftRightImplENS12_17NameBitShiftRightELb1ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clISX_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x000000000d5d1b68 6. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d4437c1 7. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d42c43b 8. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d4286c8 9. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d424d7c 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 11. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:48:15.120792 [ 3894 ] {aeafbb58-f3cf-47bd-b6e5-65ffc857b5e3} TCPHandler: Code: 69. DB::Exception: The number of shift positions needs to be a non-negative value: In scope SELECT bitShiftRight(toFixedString('hola', 8), -1). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. void DB::impl_::StringIntegerOperationImpl<_BitInt(8), DB::(anonymous namespace)::BitShiftRightImpl>::processFixedString<(DB::impl_::OpCase)0>(char8_t const*, unsigned long, DB::(anonymous namespace) const*, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x000000000d40a277 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_117BitShiftRightImplENS12_17NameBitShiftRightELb1ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clISX_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x000000000d5d1b68 6. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d4437c1 7. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d42c43b 8. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d4286c8 9. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d424d7c 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 11. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:48:15.194982 [ 3233 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:15.195009 [ 3237 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:15.261030 [ 3231 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:15.336484 [ 3232 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:15.622104 [ 3230 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:15.626096 [ 3224 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:16.196424 [ 3215 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:16.196568 [ 3216 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:16.262081 [ 3217 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:16.337541 [ 3204 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:16.403238 [ 4841 ] {420bd2fe-bb1e-40b6-a48c-6bf964229a89} executeQuery: Code: 407. DB::Exception: Decimal convert overflow. Float is out of Decimal range: In scope SELECT toDecimal32(10000.1, 6). (DECIMAL_OVERFLOW) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44452) (comment: 00700_decimal_casts_2.sql) (in query: select toDecimal32(10000.1, 6);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008460d8a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:288: _ZN2DB20convertToDecimalImplINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIiEEEEvQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEET1_RKS8_jRNS9_9FieldTypeE @ 0x0000000032505c55 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:322: _ZN2DB16convertToDecimalINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIiEEEEQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEENS9_9FieldTypeERKS8_j @ 0x000000003250b435 6. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000091f0fd3 7. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091c90df 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:48:16.405647 [ 4841 ] {420bd2fe-bb1e-40b6-a48c-6bf964229a89} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow. Float is out of Decimal range: In scope SELECT toDecimal32(10000.1, 6). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008460d8a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:288: _ZN2DB20convertToDecimalImplINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIiEEEEvQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEET1_RKS8_jRNS9_9FieldTypeE @ 0x0000000032505c55 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:322: _ZN2DB16convertToDecimalINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIiEEEEQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEENS9_9FieldTypeERKS8_j @ 0x000000003250b435 6. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000091f0fd3 7. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091c90df 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:48:16.623207 [ 3193 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:16.627042 [ 3198 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:17.197428 [ 3183 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:17.197430 [ 3180 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:17.262952 [ 3173 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:17.338743 [ 3166 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:17.624287 [ 3163 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:17.628281 [ 3148 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:18.022363 [ 3894 ] {86b55d29-c596-4b8e-b44a-01c137f53291} executeQuery: Code: 69. DB::Exception: The number of shift positions needs to be a non-negative value: In scope SELECT bitShiftLeft(1, -1). (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:43524) (comment: 03198_bit_shift_throws_error_for_out_of_bounds.sql) (in query: SELECT bitShiftLeft(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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. _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_116BitShiftLeftImplENS12_16NameBitShiftLeftELb1ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clIS2_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x000000000d165052 5. 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&&) @ 0x000000000d139fa2 6. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d12a91b 7. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d126ba8 8. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d12325c 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 2025.10.23 23:48:18.024432 [ 3894 ] {86b55d29-c596-4b8e-b44a-01c137f53291} TCPHandler: Code: 69. DB::Exception: The number of shift positions needs to be a non-negative value: In scope SELECT bitShiftLeft(1, -1). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. _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_116BitShiftLeftImplENS12_16NameBitShiftLeftELb1ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clIS2_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x000000000d165052 5. 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&&) @ 0x000000000d139fa2 6. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d12a91b 7. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d126ba8 8. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d12325c 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 2025.10.23 23:48:18.198626 [ 3154 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:18.198653 [ 3146 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:18.263973 [ 3142 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:18.340073 [ 3157 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:18.562351 [ 4841 ] {89d2c5cb-e133-4e8a-8746-61512085bc12} executeQuery: Code: 407. DB::Exception: Decimal convert overflow. Float is out of Decimal range: In scope SELECT toDecimal64(10000.1, 18). (DECIMAL_OVERFLOW) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44452) (comment: 00700_decimal_casts_2.sql) (in query: select toDecimal64(10000.1, 18);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008460d8a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:288: _ZN2DB20convertToDecimalImplINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIlEEEEvQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEET1_RKS8_jRNS9_9FieldTypeE @ 0x000000003250657b 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:322: _ZN2DB16convertToDecimalINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIlEEEEQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEENS9_9FieldTypeERKS8_j @ 0x000000003250c2d5 6. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092461ed 7. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000921d09f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:48:18.567560 [ 4841 ] {89d2c5cb-e133-4e8a-8746-61512085bc12} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow. Float is out of Decimal range: In scope SELECT toDecimal64(10000.1, 18). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008460d8a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:288: _ZN2DB20convertToDecimalImplINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIlEEEEvQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEET1_RKS8_jRNS9_9FieldTypeE @ 0x000000003250657b 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:322: _ZN2DB16convertToDecimalINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIlEEEEQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEENS9_9FieldTypeERKS8_j @ 0x000000003250c2d5 6. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092461ed 7. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000921d09f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:48:18.625283 [ 3119 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:18.629336 [ 3164 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:19.199633 [ 3127 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:19.248824 [ 3107 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:19.264763 [ 3112 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:19.341046 [ 3159 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:19.626473 [ 3102 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:19.630502 [ 3090 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:20.281279 [ 3085 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:20.281366 [ 3095 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:20.281627 [ 3075 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:20.342243 [ 3072 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:20.627672 [ 3070 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:20.632202 [ 3058 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:20.970500 [ 3894 ] {7ef5be69-bb49-4ded-98b5-12529c99110c} executeQuery: Code: 69. DB::Exception: The number of shift positions needs to be a non-negative value: In scope SELECT bitShiftLeft('hola', -1). (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:43524) (comment: 03198_bit_shift_throws_error_for_out_of_bounds.sql) (in query: SELECT bitShiftLeft('hola', -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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. void DB::impl_::StringIntegerOperationImpl<_BitInt(8), DB::(anonymous namespace)::BitShiftLeftImpl>::processString<(DB::impl_::OpCase)0>(char8_t const*, unsigned long const*, DB::(anonymous namespace) const*, DB::PODArray, 63ul, 64ul>&, Allocator, 63ul, 64ul>, 63ul, 64ul>&, unsigned long) @ 0x000000000d113595 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_116BitShiftLeftImplENS12_16NameBitShiftLeftELb1ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clISY_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x000000000d2e1d68 6. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d141e21 7. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d12a91b 8. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d126ba8 9. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d12325c 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 11. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:48:20.972446 [ 3894 ] {7ef5be69-bb49-4ded-98b5-12529c99110c} TCPHandler: Code: 69. DB::Exception: The number of shift positions needs to be a non-negative value: In scope SELECT bitShiftLeft('hola', -1). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. void DB::impl_::StringIntegerOperationImpl<_BitInt(8), DB::(anonymous namespace)::BitShiftLeftImpl>::processString<(DB::impl_::OpCase)0>(char8_t const*, unsigned long const*, DB::(anonymous namespace) const*, DB::PODArray, 63ul, 64ul>&, Allocator, 63ul, 64ul>, 63ul, 64ul>&, unsigned long) @ 0x000000000d113595 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_116BitShiftLeftImplENS12_16NameBitShiftLeftELb1ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clISY_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x000000000d2e1d68 6. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d141e21 7. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d12a91b 8. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d126ba8 9. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d12325c 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 11. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:48:21.282287 [ 3056 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:21.282439 [ 3060 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:21.283078 [ 3067 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:21.343460 [ 3427 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:21.383450 [ 4841 ] {58554b8e-d406-49fc-94a1-9fbec30dc236} executeQuery: Code: 407. DB::Exception: Decimal convert overflow. Float is out of Decimal range: In scope SELECT toDecimal128(1e21, 18). (DECIMAL_OVERFLOW) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44452) (comment: 00700_decimal_casts_2.sql) (in query: select toDecimal128(1000000000000000000000.1, 18);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008460d8a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:288: _ZN2DB20convertToDecimalImplINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIN4wide7integerILm128EiEEEEEEvQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEET1_RKSB_jRNSC_9FieldTypeE @ 0x0000000032507254 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:322: _ZN2DB16convertToDecimalINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIN4wide7integerILm128EiEEEEEEQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEENSC_9FieldTypeERKSB_j @ 0x000000003250d53c 6. bool DB::callOnIndexAndDataType>>, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000009297a64 7. DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000927189f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:48:21.385897 [ 4841 ] {58554b8e-d406-49fc-94a1-9fbec30dc236} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow. Float is out of Decimal range: In scope SELECT toDecimal128(1e21, 18). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008460d8a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:288: _ZN2DB20convertToDecimalImplINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIN4wide7integerILm128EiEEEEEEvQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEET1_RKSB_jRNSC_9FieldTypeE @ 0x0000000032507254 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:322: _ZN2DB16convertToDecimalINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIN4wide7integerILm128EiEEEEEEQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEENSC_9FieldTypeERKSB_j @ 0x000000003250d53c 6. bool DB::callOnIndexAndDataType>>, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000009297a64 7. DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000927189f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:48:21.549208 [ 4841 ] {3724b3d1-7f28-41f3-bcdc-1da1cc73f8e5} executeQuery: Code: 407. DB::Exception: Decimal convert overflow. Float is out of Decimal range: In scope SELECT toDecimal32(-10000.1, 6). (DECIMAL_OVERFLOW) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44452) (comment: 00700_decimal_casts_2.sql) (in query: select toDecimal32(-10000.1, 6);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008460d8a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:288: _ZN2DB20convertToDecimalImplINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIiEEEEvQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEET1_RKS8_jRNS9_9FieldTypeE @ 0x0000000032505c55 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:322: _ZN2DB16convertToDecimalINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIiEEEEQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEENS9_9FieldTypeERKS8_j @ 0x000000003250b435 6. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000091f0fd3 7. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091c90df 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:48:21.551359 [ 4841 ] {3724b3d1-7f28-41f3-bcdc-1da1cc73f8e5} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow. Float is out of Decimal range: In scope SELECT toDecimal32(-10000.1, 6). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008460d8a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:288: _ZN2DB20convertToDecimalImplINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIiEEEEvQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEET1_RKS8_jRNS9_9FieldTypeE @ 0x0000000032505c55 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:322: _ZN2DB16convertToDecimalINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIiEEEEQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEENS9_9FieldTypeERKS8_j @ 0x000000003250b435 6. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000091f0fd3 7. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091c90df 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:48:21.579177 [ 4841 ] {d9871311-313b-4fab-8b4c-fc183f09f3e6} executeQuery: Code: 407. DB::Exception: Decimal convert overflow. Float is out of Decimal range: In scope SELECT toDecimal64(-10000.1, 18). (DECIMAL_OVERFLOW) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44452) (comment: 00700_decimal_casts_2.sql) (in query: select toDecimal64(-10000.1, 18);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008460d8a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:288: _ZN2DB20convertToDecimalImplINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIlEEEEvQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEET1_RKS8_jRNS9_9FieldTypeE @ 0x000000003250657b 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:322: _ZN2DB16convertToDecimalINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIlEEEEQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEENS9_9FieldTypeERKS8_j @ 0x000000003250c2d5 6. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092461ed 7. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000921d09f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:48:21.581737 [ 4841 ] {d9871311-313b-4fab-8b4c-fc183f09f3e6} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow. Float is out of Decimal range: In scope SELECT toDecimal64(-10000.1, 18). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008460d8a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:288: _ZN2DB20convertToDecimalImplINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIlEEEEvQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEET1_RKS8_jRNS9_9FieldTypeE @ 0x000000003250657b 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:322: _ZN2DB16convertToDecimalINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIlEEEEQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEENS9_9FieldTypeERKS8_j @ 0x000000003250c2d5 6. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092461ed 7. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000921d09f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:48:21.629176 [ 3057 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:21.633480 [ 3391 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:21.687126 [ 4841 ] {307ba4e6-355b-448c-b31f-0e1aaf2fa47a} executeQuery: Code: 407. DB::Exception: Decimal convert overflow. Float is out of Decimal range: In scope SELECT toDecimal128(-1e21, 18). (DECIMAL_OVERFLOW) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44452) (comment: 00700_decimal_casts_2.sql) (in query: select toDecimal128(-1000000000000000000000.1, 18);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008460d8a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:288: _ZN2DB20convertToDecimalImplINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIN4wide7integerILm128EiEEEEEEvQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEET1_RKSB_jRNSC_9FieldTypeE @ 0x0000000032507254 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:322: _ZN2DB16convertToDecimalINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIN4wide7integerILm128EiEEEEEEQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEENSC_9FieldTypeERKSB_j @ 0x000000003250d53c 6. bool DB::callOnIndexAndDataType>>, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000009297a64 7. DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000927189f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:48:21.689314 [ 4841 ] {307ba4e6-355b-448c-b31f-0e1aaf2fa47a} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow. Float is out of Decimal range: In scope SELECT toDecimal128(-1e21, 18). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008460d8a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:288: _ZN2DB20convertToDecimalImplINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIN4wide7integerILm128EiEEEEEEvQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEET1_RKSB_jRNSC_9FieldTypeE @ 0x0000000032507254 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:322: _ZN2DB16convertToDecimalINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIN4wide7integerILm128EiEEEEEEQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEENSC_9FieldTypeERKSB_j @ 0x000000003250d53c 6. bool DB::callOnIndexAndDataType>>, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000009297a64 7. DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000927189f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:48:21.719639 [ 4841 ] {c92849e7-23a7-4b2c-b4f9-73aa4afd82bf} executeQuery: Code: 407. DB::Exception: Decimal convert overflow. Float is out of Decimal range: In scope SELECT toDecimal32(2147483647. + 1., 0). (DECIMAL_OVERFLOW) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44452) (comment: 00700_decimal_casts_2.sql) (in query: select toDecimal32(2147483647.0 + 1.0, 0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008460d8a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:288: _ZN2DB20convertToDecimalImplINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIiEEEEvQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEET1_RKS8_jRNS9_9FieldTypeE @ 0x0000000032505c55 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:322: _ZN2DB16convertToDecimalINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIiEEEEQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEENS9_9FieldTypeERKS8_j @ 0x000000003250b435 6. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000091f0fd3 7. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091c90df 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:48:21.721884 [ 4841 ] {c92849e7-23a7-4b2c-b4f9-73aa4afd82bf} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow. Float is out of Decimal range: In scope SELECT toDecimal32(2147483647. + 1., 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008460d8a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:288: _ZN2DB20convertToDecimalImplINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIiEEEEvQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEET1_RKS8_jRNS9_9FieldTypeE @ 0x0000000032505c55 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:322: _ZN2DB16convertToDecimalINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIiEEEEQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEENS9_9FieldTypeERKS8_j @ 0x000000003250b435 6. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000091f0fd3 7. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091c90df 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:48:21.748609 [ 4841 ] {3d2c88ad-b356-45d7-bcf7-c8e3204114b7} executeQuery: Code: 407. DB::Exception: Decimal convert overflow. Float is out of Decimal range: In scope SELECT toDecimal64(9223372036854776000., 0). (DECIMAL_OVERFLOW) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44452) (comment: 00700_decimal_casts_2.sql) (in query: select toDecimal64(9223372036854775807.0, 0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008460d8a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:288: _ZN2DB20convertToDecimalImplINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIlEEEEvQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEET1_RKS8_jRNS9_9FieldTypeE @ 0x000000003250657b 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:322: _ZN2DB16convertToDecimalINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIlEEEEQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEENS9_9FieldTypeERKS8_j @ 0x000000003250c2d5 6. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092461ed 7. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000921d09f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:48:21.751073 [ 4841 ] {3d2c88ad-b356-45d7-bcf7-c8e3204114b7} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow. Float is out of Decimal range: In scope SELECT toDecimal64(9223372036854776000., 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008460d8a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:288: _ZN2DB20convertToDecimalImplINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIlEEEEvQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEET1_RKS8_jRNS9_9FieldTypeE @ 0x000000003250657b 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:322: _ZN2DB16convertToDecimalINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIlEEEEQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEENS9_9FieldTypeERKS8_j @ 0x000000003250c2d5 6. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092461ed 7. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000921d09f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:48:21.777289 [ 4841 ] {2ccaa604-2fae-4171-aeff-fa913ecc07a8} executeQuery: Code: 407. DB::Exception: Decimal convert overflow. Float is out of Decimal range: In scope SELECT toDecimal128(1.7014118346046923e38, 0). (DECIMAL_OVERFLOW) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44452) (comment: 00700_decimal_casts_2.sql) (in query: select toDecimal128(170141183460469231731687303715884105729.0, 0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008460d8a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:288: _ZN2DB20convertToDecimalImplINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIN4wide7integerILm128EiEEEEEEvQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEET1_RKSB_jRNSC_9FieldTypeE @ 0x0000000032507254 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:322: _ZN2DB16convertToDecimalINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIN4wide7integerILm128EiEEEEEEQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEENSC_9FieldTypeERKSB_j @ 0x000000003250d53c 6. bool DB::callOnIndexAndDataType>>, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000009297a64 7. DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000927189f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:48:21.779337 [ 4841 ] {2ccaa604-2fae-4171-aeff-fa913ecc07a8} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow. Float is out of Decimal range: In scope SELECT toDecimal128(1.7014118346046923e38, 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008460d8a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:288: _ZN2DB20convertToDecimalImplINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIN4wide7integerILm128EiEEEEEEvQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEET1_RKSB_jRNSC_9FieldTypeE @ 0x0000000032507254 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:322: _ZN2DB16convertToDecimalINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIN4wide7integerILm128EiEEEEEEQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEENSC_9FieldTypeERKSB_j @ 0x000000003250d53c 6. bool DB::callOnIndexAndDataType>>, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000009297a64 7. DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000927189f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:48:21.808554 [ 4841 ] {7733653b-c487-4045-b41e-7a59feb079c4} executeQuery: Code: 407. DB::Exception: Decimal convert overflow. Float is out of Decimal range: In scope SELECT toDecimal32(-2147483647. - 1., 0). (DECIMAL_OVERFLOW) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44452) (comment: 00700_decimal_casts_2.sql) (in query: select toDecimal32(-2147483647.0 - 1.0, 0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008460d8a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:288: _ZN2DB20convertToDecimalImplINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIiEEEEvQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEET1_RKS8_jRNS9_9FieldTypeE @ 0x0000000032505c55 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:322: _ZN2DB16convertToDecimalINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIiEEEEQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEENS9_9FieldTypeERKS8_j @ 0x000000003250b435 6. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000091f0fd3 7. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091c90df 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:48:21.812464 [ 4841 ] {7733653b-c487-4045-b41e-7a59feb079c4} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow. Float is out of Decimal range: In scope SELECT toDecimal32(-2147483647. - 1., 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008460d8a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:288: _ZN2DB20convertToDecimalImplINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIiEEEEvQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEET1_RKS8_jRNS9_9FieldTypeE @ 0x0000000032505c55 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:322: _ZN2DB16convertToDecimalINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIiEEEEQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEENS9_9FieldTypeERKS8_j @ 0x000000003250b435 6. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000091f0fd3 7. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091c90df 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:48:21.838329 [ 4841 ] {3fd239d5-9e7f-47f3-8564-1e690682aaf1} executeQuery: Code: 407. DB::Exception: Decimal convert overflow. Float is out of Decimal range: In scope SELECT toDecimal64(-9223372036854776000., 0). (DECIMAL_OVERFLOW) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44452) (comment: 00700_decimal_casts_2.sql) (in query: select toDecimal64(-9223372036854775807.0, 0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008460d8a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:288: _ZN2DB20convertToDecimalImplINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIlEEEEvQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEET1_RKS8_jRNS9_9FieldTypeE @ 0x000000003250657b 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:322: _ZN2DB16convertToDecimalINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIlEEEEQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEENS9_9FieldTypeERKS8_j @ 0x000000003250c2d5 6. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092461ed 7. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000921d09f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:48:21.840913 [ 4841 ] {3fd239d5-9e7f-47f3-8564-1e690682aaf1} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow. Float is out of Decimal range: In scope SELECT toDecimal64(-9223372036854776000., 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008460d8a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:288: _ZN2DB20convertToDecimalImplINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIlEEEEvQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEET1_RKS8_jRNS9_9FieldTypeE @ 0x000000003250657b 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:322: _ZN2DB16convertToDecimalINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIlEEEEQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEENS9_9FieldTypeERKS8_j @ 0x000000003250c2d5 6. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000092461ed 7. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000921d09f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:48:21.865719 [ 4841 ] {4ffd50a8-d0e0-4e38-8858-6d8aa9c3dbca} executeQuery: Code: 407. DB::Exception: Decimal convert overflow. Float is out of Decimal range: In scope SELECT toDecimal128(-1.7014118346046923e38, 0). (DECIMAL_OVERFLOW) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44452) (comment: 00700_decimal_casts_2.sql) (in query: select toDecimal128(-170141183460469231731687303715884105729.0, 0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008460d8a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:288: _ZN2DB20convertToDecimalImplINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIN4wide7integerILm128EiEEEEEEvQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEET1_RKSB_jRNSC_9FieldTypeE @ 0x0000000032507254 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:322: _ZN2DB16convertToDecimalINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIN4wide7integerILm128EiEEEEEEQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEENSC_9FieldTypeERKSB_j @ 0x000000003250d53c 6. bool DB::callOnIndexAndDataType>>, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000009297a64 7. DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000927189f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:48:21.867650 [ 4841 ] {4ffd50a8-d0e0-4e38-8858-6d8aa9c3dbca} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow. Float is out of Decimal range: In scope SELECT toDecimal128(-1.7014118346046923e38, 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008460d8a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:288: _ZN2DB20convertToDecimalImplINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIN4wide7integerILm128EiEEEEEEvQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEET1_RKSB_jRNSC_9FieldTypeE @ 0x0000000032507254 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:322: _ZN2DB16convertToDecimalINS_14DataTypeNumberIdEENS_15DataTypeDecimalINS_7DecimalIN4wide7integerILm128EiEEEEEEQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEENSC_9FieldTypeERKSB_j @ 0x000000003250d53c 6. bool DB::callOnIndexAndDataType>>, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000009297a64 7. DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000927189f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:48:22.170146 [ 2903 ] {7ea2dbca-1dcc-4ab5-ac77-ea0036c394ec} 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.10542.altinitytest (altinity build)) (from [::1]:39238) (comment: 02877_optimize_read_in_order_from_view.sh) (in query: SELECT read_rows FROM system.query_log WHERE current_database = currentDatabase() AND query_id='test_1_optimize_read_in_order_from_view_80676565' AND type='QueryFinish'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 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) @ 0x0000000039c89948 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000003999bfb7 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 @ 0x00000000399942f0 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039d46d05 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003bfd663a 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c083c53 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003bfe2b53 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d3c440 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf89b85 18. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 19. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 23. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 24. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 26. ? @ 0x00007f100c857ac3 27. ? @ 0x00007f100c8e9850 2025.10.23 23:48:22.176956 [ 2903 ] {7ea2dbca-1dcc-4ab5-ac77-ea0036c394ec} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 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) @ 0x0000000039c89948 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000003999bfb7 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 @ 0x00000000399942f0 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039d46d05 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003bfd663a 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c083c53 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003bfe2b53 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d3c440 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf89b85 18. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 19. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 23. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 24. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 26. ? @ 0x00007f100c857ac3 27. ? @ 0x00007f100c8e9850 2025.10.23 23:48:22.283111 [ 3291 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:22.283622 [ 3213 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:22.284451 [ 3063 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:22.344919 [ 3203 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:22.630593 [ 3563 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:22.634671 [ 3207 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:23.284035 [ 3556 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:23.286029 [ 3552 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:23.286087 [ 3536 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:23.345913 [ 3534 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:23.631863 [ 3545 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:23.636024 [ 3529 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:24.284959 [ 3546 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:24.286914 [ 3519 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:24.287011 [ 3523 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:24.347200 [ 3516 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:24.475613 [ 3894 ] {c71625c4-6069-4d40-bfd6-509e31471c22} executeQuery: Code: 69. DB::Exception: The number of shift positions needs to be a non-negative value: In scope SELECT bitShiftLeft(toFixedString('hola', 8), -1). (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:43524) (comment: 03198_bit_shift_throws_error_for_out_of_bounds.sql) (in query: SELECT bitShiftLeft(toFixedString('hola', 8), -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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. void DB::impl_::StringIntegerOperationImpl<_BitInt(8), DB::(anonymous namespace)::BitShiftLeftImpl>::processFixedString<(DB::impl_::OpCase)0>(char8_t const*, unsigned long, DB::(anonymous namespace) const*, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x000000000d0fada9 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_116BitShiftLeftImplENS12_16NameBitShiftLeftELb1ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clISX_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x000000000d2d1a08 6. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d141ca1 7. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d12a91b 8. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d126ba8 9. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d12325c 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 11. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:48:24.477411 [ 3894 ] {c71625c4-6069-4d40-bfd6-509e31471c22} TCPHandler: Code: 69. DB::Exception: The number of shift positions needs to be a non-negative value: In scope SELECT bitShiftLeft(toFixedString('hola', 8), -1). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. void DB::impl_::StringIntegerOperationImpl<_BitInt(8), DB::(anonymous namespace)::BitShiftLeftImpl>::processFixedString<(DB::impl_::OpCase)0>(char8_t const*, unsigned long, DB::(anonymous namespace) const*, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x000000000d0fada9 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_116BitShiftLeftImplENS12_16NameBitShiftLeftELb1ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clISX_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x000000000d2d1a08 6. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d141ca1 7. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d12a91b 8. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d126ba8 9. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d12325c 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 11. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:48:24.633051 [ 3511 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:24.637838 [ 3509 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:25.286001 [ 3486 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:25.287858 [ 3483 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:25.288320 [ 3479 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:25.348831 [ 3478 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:25.634280 [ 3469 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:25.639160 [ 3473 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:26.230763 [ 3894 ] {8c1e3c47-5a9e-4cf0-bc07-225c1a98e653} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:46496) (comment: 01636_nullable_fuzz2.sql) (in query: SELECT `__table1`.`EventDate` AS `EventDate` FROM `test_1`.`open_events_tmp` AS `__table1` WHERE (`__table1`.`EventDate` <= _CAST(18455, 'Date')) AND (`__table1`.`APIKey` = 2) GROUP BY `__table1`.`EventDate` WITH TOTALS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:48:26.236443 [ 3894 ] {8c1e3c47-5a9e-4cf0-bc07-225c1a98e653} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:48:26.244544 [ 29264 ] {a6598dde-b340-4cb7-9fd9-635a0d0deb61} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:39252) (comment: 01636_nullable_fuzz2.sql) (in query: SELECT EventDate FROM ( SELECT EventDate FROM tracking_events_tmp AS t1 WHERE (EventDate >= toDate('2020-07-09')) AND (EventDate <= toDate('2020-07-11')) AND (APIKey = 2) GROUP BY EventDate ) FULL OUTER JOIN ( SELECT EventDate FROM remote('127.0.0.{1,3}', currentDatabase(), open_events_tmp) AS t2 WHERE (EventDate <= toDate('2020-07-12')) AND (APIKey = 2) GROUP BY EventDate WITH TOTALS ) USING (EventDate) ORDER BY EventDate ASC SETTINGS totals_mode = 'after_having_auto', group_by_overflow_mode = 'any', max_rows_to_group_by = 10000000, 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002019af32 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000003a7e3e0c 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::Connection::receivePacket() @ 0x000000003a7ff61b 5. ./build_docker/./src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003a8ed7f8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000323566d1 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032355a26 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000032352f12 2025.10.23 23:48:26.260929 [ 29264 ] {a6598dde-b340-4cb7-9fd9-635a0d0deb61} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 : 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002019af32 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000003a7e3e0c 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::Connection::receivePacket() @ 0x000000003a7ff61b 5. ./build_docker/./src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003a8ed7f8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000323566d1 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032355a26 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000032352f12 2025.10.23 23:48:26.287036 [ 3453 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:26.288545 [ 3448 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:26.289143 [ 3454 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:26.350045 [ 3450 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:26.635131 [ 3437 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:26.640116 [ 3429 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:27.287881 [ 3415 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:27.289208 [ 3414 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:27.289884 [ 3417 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:27.351090 [ 3411 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:27.636094 [ 3399 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:27.640872 [ 3395 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:28.288621 [ 3383 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:28.289831 [ 3375 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:28.291025 [ 3369 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:28.352079 [ 3367 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:28.637246 [ 3360 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:28.642042 [ 3364 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:29.289718 [ 3336 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:29.290822 [ 3365 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:29.292065 [ 3326 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:29.429034 [ 3328 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:29.541352 [ 29264 ] {063d6d75-d90d-4dc5-b9bb-833a9d5a0a57} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseReadableSize doesn't match: passed 0, should be 1: In scope SELECT parseReadableSize(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:52076) (comment: 03165_parseReadableSize.sql) (in query: -- ERRORS -- No arguments SELECT parseReadableSize();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000b60d377 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000b609265 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60a3eb 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b609cba 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60b9ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334af94d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 30. ? @ 0x00007f100c857ac3 31. ? @ 0x00007f100c8e9850 2025.10.23 23:48:29.542715 [ 29264 ] {063d6d75-d90d-4dc5-b9bb-833a9d5a0a57} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseReadableSize doesn't match: passed 0, should be 1: In scope SELECT parseReadableSize(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000b60d377 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000b609265 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60a3eb 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b609cba 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60b9ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334af94d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 30. ? @ 0x00007f100c857ac3 31. ? @ 0x00007f100c8e9850 2025.10.23 23:48:29.558737 [ 29264 ] {a9ca4ee6-eda3-406d-a76d-ad198eb5c73a} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseReadableSize doesn't match: passed 2, should be 1: In scope SELECT parseReadableSize('1 B', '2 B'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:52076) (comment: 03165_parseReadableSize.sql) (in query: -- Too many arguments SELECT parseReadableSize('1 B', '2 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000b60d377 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000b609265 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60a3eb 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b609cba 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60b9ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334af94d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 30. ? @ 0x00007f100c857ac3 31. ? @ 0x00007f100c8e9850 2025.10.23 23:48:29.560098 [ 29264 ] {a9ca4ee6-eda3-406d-a76d-ad198eb5c73a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseReadableSize doesn't match: passed 2, should be 1: In scope SELECT parseReadableSize('1 B', '2 B'). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000b60d377 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000b609265 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60a3eb 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b609cba 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60b9ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334af94d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 30. ? @ 0x00007f100c857ac3 31. ? @ 0x00007f100c8e9850 2025.10.23 23:48:29.638363 [ 3335 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:29.643388 [ 3348 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:30.290904 [ 3297 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:30.291942 [ 3297 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:30.292961 [ 3308 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:30.430247 [ 3302 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:30.639586 [ 3289 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:30.644713 [ 3286 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:30.789681 [ 2903 ] {c7b6890e-7935-4628-8060-15548bb197a1} 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.10542.altinitytest (altinity build)) (from [::1]:52062) (comment: 00871_t64_codec_signed.sql) (in query: SELECT * FROM t64 ORDER BY i64;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000039d07892 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&) @ 0x0000000039d09d4a 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:63: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x00000000326402a2 12. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:0: DB::SerializationSparse::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000003282ef45 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000032640cad 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000039d01224 15. ./contrib/llvm-project/libcxx/include/vector:547: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000039d00b49 16. ./contrib/llvm-project/libcxx/include/__tree:1088: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) @ 0x00000000399bb1c8 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 @ 0x00000000399b0254 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039d45fb0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003bfd663a 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c083c53 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003bfe2b53 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d3c440 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf89b85 24. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 25. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 29. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 2025.10.23 23:48:30.814383 [ 2903 ] {c7b6890e-7935-4628-8060-15548bb197a1} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000039d07892 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&) @ 0x0000000039d09d4a 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:63: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x00000000326402a2 12. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:0: DB::SerializationSparse::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000003282ef45 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000032640cad 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000039d01224 15. ./contrib/llvm-project/libcxx/include/vector:547: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000039d00b49 16. ./contrib/llvm-project/libcxx/include/__tree:1088: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) @ 0x00000000399bb1c8 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 @ 0x00000000399b0254 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039d45fb0 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003bfd663a 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c083c53 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003bfe2b53 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d3c440 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf89b85 24. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 25. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 29. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 2025.10.23 23:48:31.161081 [ 29264 ] {3572482d-9f55-4aca-b124-b120bac1b92d} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'readable_size' to function 'parseReadableSize'. Expected: String, got: UInt8: In scope SELECT parseReadableSize(12). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:52076) (comment: 03165_parseReadableSize.sql) (in query: -- Wrong Type SELECT parseReadableSize(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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084076a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000084008e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fefba 6. DB::FunctionParseReadable::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019c8c40b 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083d29bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60aa37 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b609cba 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60b9ac 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334af94d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 2025.10.23 23:48:31.163163 [ 29264 ] {3572482d-9f55-4aca-b124-b120bac1b92d} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'readable_size' to function 'parseReadableSize'. Expected: String, got: UInt8: In scope SELECT parseReadableSize(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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000084076a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000084008e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083fefba 6. DB::FunctionParseReadable::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019c8c40b 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083d29bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60aa37 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b609cba 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60b9ac 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334af94d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 2025.10.23 23:48:31.292260 [ 3274 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:31.292644 [ 3261 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:31.293870 [ 3264 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:31.362650 [ 4841 ] {b13d71ae-83ba-4c14-b6a8-47103e970c3b} executeQuery: Code: 207. DB::Exception: JOIN LEFT JOIN ... ON a.color_key = c.color_key ambiguous identifier 'color_key'. In scope SELECT id, animal_name, a.animal_key, color_name, color_key FROM fact AS a LEFT JOIN (SELECT toInt64(animal_key) AS animal_key, animal_name FROM animals) AS b ON a.animal_key = b.animal_key LEFT JOIN (SELECT toInt64(color_key) AS color_key, color_name FROM colors) AS c ON a.color_key = c.color_key. (AMBIGUOUS_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:52090) (comment: 03058_analyzer_ambiguous_columns.sql) (in query: select id, animal_name, a.animal_key, color_name, color_key from fact a left join (select toInt64(animal_key) animal_key, animal_name from animals) b on (a.animal_key = b.animal_key) left join (select toInt64(color_key) color_key, color_name from colors) c on (a.color_key = c.color_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000033502a57 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1186: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335c6f2d 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335c7a6a 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000335cebe7 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1396: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x000000003348369d 8. ./src/Analyzer/Resolve/IdentifierLookup.h:47: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033450173 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 11. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 2025.10.23 23:48:31.431670 [ 3262 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:31.461244 [ 4841 ] {b13d71ae-83ba-4c14-b6a8-47103e970c3b} TCPHandler: Code: 207. DB::Exception: JOIN LEFT JOIN ... ON a.color_key = c.color_key ambiguous identifier 'color_key'. In scope SELECT id, animal_name, a.animal_key, color_name, color_key FROM fact AS a LEFT JOIN (SELECT toInt64(animal_key) AS animal_key, animal_name FROM animals) AS b ON a.animal_key = b.animal_key LEFT JOIN (SELECT toInt64(color_key) AS color_key, color_name FROM colors) AS c ON a.color_key = c.color_key. (AMBIGUOUS_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000033502a57 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1186: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335c6f2d 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335c7a6a 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000335cebe7 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1396: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x000000003348369d 8. ./src/Analyzer/Resolve/IdentifierLookup.h:47: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033450173 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 11. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 2025.10.23 23:48:31.640913 [ 3248 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:31.645833 [ 3256 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:32.293743 [ 3215 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:32.293805 [ 3217 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:32.294876 [ 3211 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:32.433060 [ 3190 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:32.642059 [ 3191 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:32.646912 [ 3184 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:33.294806 [ 3178 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:33.295293 [ 3171 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:33.296575 [ 3170 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:33.434262 [ 3156 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:33.643201 [ 3158 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:33.648317 [ 3161 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:34.099177 [ 4841 ] {964c44a7-df63-4ca4-b87d-c94d362e1999} executeQuery: Code: 207. DB::Exception: JOIN LEFT JOIN ... ON a.animal_key = b.animal_key ambiguous identifier 'animal_key'. In scope SELECT id, animal_name, animal_key, color_name, color_key FROM fact AS a LEFT JOIN (SELECT toInt64(animal_key) AS animal_key, animal_name FROM animals) AS b ON a.animal_key = b.animal_key LEFT JOIN (SELECT toInt64(color_key) AS color_key, color_name FROM colors) AS c ON a.color_key = c.color_key. (AMBIGUOUS_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:52090) (comment: 03058_analyzer_ambiguous_columns.sql) (in query: select id, animal_name, animal_key, color_name, color_key from fact a left join (select toInt64(animal_key) animal_key, animal_name from animals) b on (a.animal_key = b.animal_key) left join (select toInt64(color_key) color_key, color_name from colors) c on (a.color_key = c.color_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000033502a57 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1186: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335c6f2d 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335c7a6a 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1002: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335c2fc4 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335c7a6a 8. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000335cebe7 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1396: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x000000003348369d 10. ./src/Analyzer/Resolve/IdentifierLookup.h:47: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033450173 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 31. ? @ 0x00007f100c857ac3 2025.10.23 23:48:34.101732 [ 4841 ] {964c44a7-df63-4ca4-b87d-c94d362e1999} TCPHandler: Code: 207. DB::Exception: JOIN LEFT JOIN ... ON a.animal_key = b.animal_key ambiguous identifier 'animal_key'. In scope SELECT id, animal_name, animal_key, color_name, color_key FROM fact AS a LEFT JOIN (SELECT toInt64(animal_key) AS animal_key, animal_name FROM animals) AS b ON a.animal_key = b.animal_key LEFT JOIN (SELECT toInt64(color_key) AS color_key, color_name FROM colors) AS c ON a.color_key = c.color_key. (AMBIGUOUS_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000033502a57 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1186: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335c6f2d 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335c7a6a 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1002: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335c2fc4 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335c7a6a 8. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000335cebe7 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1396: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x000000003348369d 10. ./src/Analyzer/Resolve/IdentifierLookup.h:47: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033450173 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 31. ? @ 0x00007f100c857ac3 2025.10.23 23:48:34.295897 [ 3128 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:34.296315 [ 3136 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:34.297502 [ 3121 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:34.435435 [ 3119 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:34.438625 [ 29264 ] {4075b759-7c61-4cf4-92c9-ae3c52852341} executeQuery: Code: 72. DB::Exception: Invalid expression for function parseReadableSize - Unable to parse readable size numeric component ("oh no"): In scope SELECT parseReadableSize('oh no'). (CANNOT_PARSE_NUMBER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:52076) (comment: 03165_parseReadableSize.sql) (in query: -- Invalid input - overall garbage SELECT parseReadableSize('oh no');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type>, String&&, std::basic_string_view> const&) @ 0x00000000086835ed 4. DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x0000000019c8dc95 5. DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000019c8b9ca 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 2025.10.23 23:48:34.501700 [ 29264 ] {4075b759-7c61-4cf4-92c9-ae3c52852341} TCPHandler: Code: 72. DB::Exception: Invalid expression for function parseReadableSize - Unable to parse readable size numeric component ("oh no"): In scope SELECT parseReadableSize('oh no'). (CANNOT_PARSE_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type>, String&&, std::basic_string_view> const&) @ 0x00000000086835ed 4. DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x0000000019c8dc95 5. DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000019c8b9ca 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 2025.10.23 23:48:34.645029 [ 3130 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:34.649531 [ 3108 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:35.118375 [ 4841 ] {2f74bab4-63f7-4ab9-8480-04e33d3913f1} executeQuery: Code: 57. DB::Exception: Table test_15.join_test already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:52132) (comment: 01240_join_get_or_null.sql) (in query: CREATE TABLE join_test (id UInt16, num Nullable(UInt16)) engine = Join(ANY, LEFT, 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:48:35.121172 [ 4841 ] {2f74bab4-63f7-4ab9-8480-04e33d3913f1} TCPHandler: Code: 57. DB::Exception: Table test_15.join_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:48:35.297056 [ 3100 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:35.297061 [ 3093 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:35.298323 [ 3094 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:35.436784 [ 3083 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:35.645951 [ 3085 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:35.650480 [ 3095 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:36.298596 [ 3062 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:36.298956 [ 3104 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:36.299358 [ 3066 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:36.437921 [ 3069 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:36.647301 [ 3427 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:36.651396 [ 3396 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:36.950464 [ 29264 ] {9cf7021f-4ddc-458f-b2c3-490768160f7b} executeQuery: Code: 6. DB::Exception: Invalid expression for function parseReadableSize - Unknown readable size unit ("rb"): In scope SELECT parseReadableSize('12.3 rb'). (CANNOT_PARSE_TEXT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:52076) (comment: 03165_parseReadableSize.sql) (in query: -- Invalid input - unknown unit SELECT parseReadableSize('12.3 rb');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000df2a32d 4. DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x0000000019c8e230 5. DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000019c8b9ca 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 2025.10.23 23:48:36.952183 [ 29264 ] {9cf7021f-4ddc-458f-b2c3-490768160f7b} TCPHandler: Code: 6. DB::Exception: Invalid expression for function parseReadableSize - Unknown readable size unit ("rb"): In scope SELECT parseReadableSize('12.3 rb'). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000df2a32d 4. DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x0000000019c8e230 5. DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000019c8b9ca 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 2025.10.23 23:48:37.299459 [ 3197 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:37.300293 [ 3203 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:37.300741 [ 3168 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:37.438918 [ 3538 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:37.652397 [ 3111 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:37.658877 [ 3544 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:38.300280 [ 3545 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:38.300981 [ 3532 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:38.301649 [ 3529 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:38.439829 [ 3558 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:38.533042 [ 30720 ] {f785acb8-82c4-4573-b88a-a49ce6587f7d} executeQuery: Code: 42. DB::Exception: Number of arguments for function BLAKE3 doesn't match: passed 3, should be 1: In scope SELECT BLAKE3(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT BLAKE3(NULL, NULL, NULL);) 2025.10.23 23:48:38.535142 [ 30720 ] {f785acb8-82c4-4573-b88a-a49ce6587f7d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function BLAKE3 doesn't match: passed 3, should be 1: In scope SELECT BLAKE3(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:38.578797 [ 30720 ] {04c65eb0-717e-4b85-a9c8-1d71ab32f8f5} executeQuery: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 3, should be 1: In scope SELECT CHARACTER_LENGTH(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT CHARACTER_LENGTH(NULL, NULL, NULL);) 2025.10.23 23:48:38.581208 [ 30720 ] {04c65eb0-717e-4b85-a9c8-1d71ab32f8f5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 3, should be 1: In scope SELECT CHARACTER_LENGTH(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:38.653224 [ 3525 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:38.659567 [ 3549 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:38.677446 [ 30720 ] {2b947f20-ff90-4283-b142-9e631b4267eb} executeQuery: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 3, should be 1: In scope SELECT CHAR_LENGTH(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT CHAR_LENGTH(NULL, NULL, NULL);) 2025.10.23 23:48:38.679970 [ 30720 ] {2b947f20-ff90-4283-b142-9e631b4267eb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 3, should be 1: In scope SELECT CHAR_LENGTH(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:38.948535 [ 30720 ] {9ccd4afc-58c3-4417-83e8-3fdaf4d1dc9e} executeQuery: Code: 42. DB::Exception: Number of arguments for function CRC32 doesn't match: passed 3, should be 1: In scope SELECT CRC32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT CRC32(NULL, NULL, NULL);) 2025.10.23 23:48:38.953130 [ 30720 ] {9ccd4afc-58c3-4417-83e8-3fdaf4d1dc9e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function CRC32 doesn't match: passed 3, should be 1: In scope SELECT CRC32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:39.055611 [ 30720 ] {eb5fb9ea-78af-4c6e-b9c3-2d5dd52bf28e} executeQuery: Code: 42. DB::Exception: Number of arguments for function CRC32IEEE doesn't match: passed 3, should be 1: In scope SELECT CRC32IEEE(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT CRC32IEEE(NULL, NULL, NULL);) 2025.10.23 23:48:39.060422 [ 30720 ] {eb5fb9ea-78af-4c6e-b9c3-2d5dd52bf28e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function CRC32IEEE doesn't match: passed 3, should be 1: In scope SELECT CRC32IEEE(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:39.106514 [ 30720 ] {5b19bd7a-2387-4699-bebe-cb329acfd11d} executeQuery: Code: 42. DB::Exception: Number of arguments for function CRC64 doesn't match: passed 3, should be 1: In scope SELECT CRC64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT CRC64(NULL, NULL, NULL);) 2025.10.23 23:48:39.110594 [ 30720 ] {5b19bd7a-2387-4699-bebe-cb329acfd11d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function CRC64 doesn't match: passed 3, should be 1: In scope SELECT CRC64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:39.278693 [ 30720 ] {f72daab9-d858-4794-af5e-e9e2c6ee5f00} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 3, should be 0: In scope SELECT DATABASE(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT DATABASE(NULL, NULL, NULL);) 2025.10.23 23:48:39.301119 [ 3508 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:39.301864 [ 3505 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:39.302449 [ 3510 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:39.350768 [ 30720 ] {f72daab9-d858-4794-af5e-e9e2c6ee5f00} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 3, should be 0: In scope SELECT DATABASE(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:39.441097 [ 3513 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:39.643376 [ 29264 ] {aaa4bf18-6b75-4efe-b458-f08782a59d33} executeQuery: Code: 27. DB::Exception: Invalid expression for function parseReadableSize - Leading whitespace is not allowed (" 1 B"): In scope SELECT parseReadableSize(' 1 B'). (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:52076) (comment: 03165_parseReadableSize.sql) (in query: -- Invalid input - Leading whitespace SELECT parseReadableSize(' 1 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type>, String&&, std::basic_string_view> const&) @ 0x00000000086835ed 4. DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x0000000019c8dabf 5. DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000019c8b9ca 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 2025.10.23 23:48:39.646320 [ 29264 ] {aaa4bf18-6b75-4efe-b458-f08782a59d33} TCPHandler: Code: 27. DB::Exception: Invalid expression for function parseReadableSize - Leading whitespace is not allowed (" 1 B"): In scope SELECT parseReadableSize(' 1 B'). (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type>, String&&, std::basic_string_view> const&) @ 0x00000000086835ed 4. DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x0000000019c8dabf 5. DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000019c8b9ca 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 2025.10.23 23:48:39.654468 [ 3497 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:39.660641 [ 3504 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:40.302354 [ 3475 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:40.303151 [ 3490 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:40.303396 [ 3477 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:40.314557 [ 30720 ] {1a35a398-1915-4633-b694-1d5de361782d} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatReadableSize doesn't match: passed 3, should be 1: In scope SELECT FORMAT_BYTES(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT FORMAT_BYTES(NULL, NULL, NULL);) 2025.10.23 23:48:40.318750 [ 30720 ] {1a35a398-1915-4633-b694-1d5de361782d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatReadableSize doesn't match: passed 3, should be 1: In scope SELECT FORMAT_BYTES(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:40.357140 [ 30720 ] {fe18eb66-ce03-4490-88ac-32ba6d8978ac} executeQuery: Code: 42. DB::Exception: Number of arguments for function FQDN doesn't match: passed 3, should be 0: In scope SELECT FQDN(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT FQDN(NULL, NULL, NULL);) 2025.10.23 23:48:40.360495 [ 30720 ] {fe18eb66-ce03-4490-88ac-32ba6d8978ac} TCPHandler: Code: 42. DB::Exception: Number of arguments for function FQDN doesn't match: passed 3, should be 0: In scope SELECT FQDN(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:40.433015 [ 30720 ] {cf666902-0536-42fa-b6c3-d417b7d957e0} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64Decode doesn't match: passed 3, should be 1: In scope SELECT FROM_BASE64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT FROM_BASE64(NULL, NULL, NULL);) 2025.10.23 23:48:40.436717 [ 30720 ] {cf666902-0536-42fa-b6c3-d417b7d957e0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64Decode doesn't match: passed 3, should be 1: In scope SELECT FROM_BASE64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:40.442492 [ 3472 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:40.472816 [ 30720 ] {e731624a-c10c-48fd-8623-1b7eab63ad6c} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero doesn't match: passed 3, should be 1: In scope SELECT FROM_DAYS(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT FROM_DAYS(NULL, NULL, NULL);) 2025.10.23 23:48:40.510011 [ 30720 ] {e731624a-c10c-48fd-8623-1b7eab63ad6c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero doesn't match: passed 3, should be 1: In scope SELECT FROM_DAYS(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:40.661599 [ 3463 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:40.718779 [ 3465 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:40.757132 [ 30720 ] {c466da1e-31f7-4a43-b9de-d39f0fccce2d} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNum doesn't match: passed 3, should be 1: In scope SELECT INET6_ATON(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT INET6_ATON(NULL, NULL, NULL);) 2025.10.23 23:48:40.760304 [ 30720 ] {c466da1e-31f7-4a43-b9de-d39f0fccce2d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNum doesn't match: passed 3, should be 1: In scope SELECT INET6_ATON(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:40.788206 [ 30720 ] {ba4a4cf6-9524-4ffe-a69b-89df4ae610e8} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6NumToString doesn't match: passed 3, should be 1: In scope SELECT INET6_NTOA(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT INET6_NTOA(NULL, NULL, NULL);) 2025.10.23 23:48:40.791246 [ 30720 ] {ba4a4cf6-9524-4ffe-a69b-89df4ae610e8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6NumToString doesn't match: passed 3, should be 1: In scope SELECT INET6_NTOA(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:40.863986 [ 30720 ] {69e48a4b-023c-400a-a727-c204431dd629} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNum doesn't match: passed 3, should be 1: In scope SELECT INET_ATON(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT INET_ATON(NULL, NULL, NULL);) 2025.10.23 23:48:40.877969 [ 30720 ] {69e48a4b-023c-400a-a727-c204431dd629} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNum doesn't match: passed 3, should be 1: In scope SELECT INET_ATON(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:40.915007 [ 30720 ] {e8cd5db2-2b3f-496a-bdbc-48febe3cf62a} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4NumToString doesn't match: passed 3, should be 1: In scope SELECT INET_NTOA(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT INET_NTOA(NULL, NULL, NULL);) 2025.10.23 23:48:40.918673 [ 30720 ] {e8cd5db2-2b3f-496a-bdbc-48febe3cf62a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4NumToString doesn't match: passed 3, should be 1: In scope SELECT INET_NTOA(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:41.054316 [ 30720 ] {19393165-45c8-4aa2-96c1-3a6ab8c92916} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4CIDRToRange doesn't match: passed 3, should be 2: In scope SELECT IPv4CIDRToRange(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT IPv4CIDRToRange(NULL, NULL, NULL);) 2025.10.23 23:48:41.056962 [ 30720 ] {19393165-45c8-4aa2-96c1-3a6ab8c92916} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4CIDRToRange doesn't match: passed 3, should be 2: In scope SELECT IPv4CIDRToRange(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:41.088414 [ 30720 ] {0ad6172e-bf44-4869-abe3-73e3900caf78} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4NumToString doesn't match: passed 3, should be 1: In scope SELECT IPv4NumToString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT IPv4NumToString(NULL, NULL, NULL);) 2025.10.23 23:48:41.090999 [ 30720 ] {0ad6172e-bf44-4869-abe3-73e3900caf78} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4NumToString doesn't match: passed 3, should be 1: In scope SELECT IPv4NumToString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:41.130545 [ 30720 ] {3b4a9c58-7cb8-4a2c-ad48-a19814047da4} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4NumToStringClassC doesn't match: passed 3, should be 1: In scope SELECT IPv4NumToStringClassC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT IPv4NumToStringClassC(NULL, NULL, NULL);) 2025.10.23 23:48:41.134481 [ 30720 ] {3b4a9c58-7cb8-4a2c-ad48-a19814047da4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4NumToStringClassC doesn't match: passed 3, should be 1: In scope SELECT IPv4NumToStringClassC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:41.262800 [ 30720 ] {e64a2805-25b2-419a-9cc4-a16be5822572} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNum doesn't match: passed 3, should be 1: In scope SELECT IPv4StringToNum(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT IPv4StringToNum(NULL, NULL, NULL);) 2025.10.23 23:48:41.267008 [ 30720 ] {e64a2805-25b2-419a-9cc4-a16be5822572} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNum doesn't match: passed 3, should be 1: In scope SELECT IPv4StringToNum(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:41.303563 [ 3454 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:41.304383 [ 3450 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:41.304426 [ 3439 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:41.315883 [ 30720 ] {4cc1c332-699b-4804-a521-0cc8d60a7fe4} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNumOrDefault doesn't match: passed 3, should be 1: In scope SELECT IPv4StringToNumOrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT IPv4StringToNumOrDefault(NULL, NULL, NULL);) 2025.10.23 23:48:41.319611 [ 30720 ] {4cc1c332-699b-4804-a521-0cc8d60a7fe4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNumOrDefault doesn't match: passed 3, should be 1: In scope SELECT IPv4StringToNumOrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:41.367270 [ 30720 ] {a9f62bc0-a7a8-4bc6-9488-570b4efc7a09} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNumOrNull doesn't match: passed 3, should be 1: In scope SELECT IPv4StringToNumOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT IPv4StringToNumOrNull(NULL, NULL, NULL);) 2025.10.23 23:48:41.371238 [ 30720 ] {a9f62bc0-a7a8-4bc6-9488-570b4efc7a09} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNumOrNull doesn't match: passed 3, should be 1: In scope SELECT IPv4StringToNumOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:41.426099 [ 30720 ] {6e88a7c6-901b-42ba-a7ef-b35fde7c8945} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4ToIPv6 doesn't match: passed 3, should be 1: In scope SELECT IPv4ToIPv6(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT IPv4ToIPv6(NULL, NULL, NULL);) 2025.10.23 23:48:41.429757 [ 30720 ] {6e88a7c6-901b-42ba-a7ef-b35fde7c8945} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4ToIPv6 doesn't match: passed 3, should be 1: In scope SELECT IPv4ToIPv6(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:41.444035 [ 3449 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:41.468695 [ 30720 ] {18ef9f08-09ae-44d0-96d2-049dbb588a4b} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6CIDRToRange doesn't match: passed 3, should be 2: In scope SELECT IPv6CIDRToRange(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT IPv6CIDRToRange(NULL, NULL, NULL);) 2025.10.23 23:48:41.472630 [ 30720 ] {18ef9f08-09ae-44d0-96d2-049dbb588a4b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6CIDRToRange doesn't match: passed 3, should be 2: In scope SELECT IPv6CIDRToRange(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:41.509163 [ 30720 ] {c26e8410-4735-4b59-8515-e28ce0f29665} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6NumToString doesn't match: passed 3, should be 1: In scope SELECT IPv6NumToString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT IPv6NumToString(NULL, NULL, NULL);) 2025.10.23 23:48:41.512877 [ 30720 ] {c26e8410-4735-4b59-8515-e28ce0f29665} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6NumToString doesn't match: passed 3, should be 1: In scope SELECT IPv6NumToString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:41.548842 [ 30720 ] {ae3e0c0d-f86c-4ff3-ab6c-b651cf36655c} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNum doesn't match: passed 3, should be 1: In scope SELECT IPv6StringToNum(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT IPv6StringToNum(NULL, NULL, NULL);) 2025.10.23 23:48:41.552523 [ 30720 ] {ae3e0c0d-f86c-4ff3-ab6c-b651cf36655c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNum doesn't match: passed 3, should be 1: In scope SELECT IPv6StringToNum(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:41.634597 [ 30720 ] {485086d8-b9bd-494c-91c1-b7fb771d82dc} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNumOrDefault doesn't match: passed 3, should be 1: In scope SELECT IPv6StringToNumOrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT IPv6StringToNumOrDefault(NULL, NULL, NULL);) 2025.10.23 23:48:41.639372 [ 30720 ] {485086d8-b9bd-494c-91c1-b7fb771d82dc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNumOrDefault doesn't match: passed 3, should be 1: In scope SELECT IPv6StringToNumOrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:41.662816 [ 3440 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:41.686881 [ 30720 ] {f4a6637f-c3a3-43a6-b001-7b133b66bfbe} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNumOrNull doesn't match: passed 3, should be 1: In scope SELECT IPv6StringToNumOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT IPv6StringToNumOrNull(NULL, NULL, NULL);) 2025.10.23 23:48:41.690350 [ 30720 ] {f4a6637f-c3a3-43a6-b001-7b133b66bfbe} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNumOrNull doesn't match: passed 3, should be 1: In scope SELECT IPv6StringToNumOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:41.720424 [ 3437 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:41.729990 [ 30720 ] {b2224a29-f0fe-43fe-ba93-2c1b689163c5} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONAllPaths doesn't match: passed 3, should be 1: In scope SELECT JSONAllPaths(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT JSONAllPaths(NULL, NULL, NULL);) 2025.10.23 23:48:41.732692 [ 30720 ] {b2224a29-f0fe-43fe-ba93-2c1b689163c5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONAllPaths doesn't match: passed 3, should be 1: In scope SELECT JSONAllPaths(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:41.854766 [ 30720 ] {bb07579c-6bc5-41b9-9b20-0b19f400ee23} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONAllPathsWithTypes doesn't match: passed 3, should be 1: In scope SELECT JSONAllPathsWithTypes(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT JSONAllPathsWithTypes(NULL, NULL, NULL);) 2025.10.23 23:48:41.858526 [ 30720 ] {bb07579c-6bc5-41b9-9b20-0b19f400ee23} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONAllPathsWithTypes doesn't match: passed 3, should be 1: In scope SELECT JSONAllPathsWithTypes(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:41.904556 [ 30720 ] {42dd15c2-01d4-43b3-99e7-19546c6d348f} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONArrayLength doesn't match: passed 3, should be 1: In scope SELECT JSONArrayLength(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT JSONArrayLength(NULL, NULL, NULL);) 2025.10.23 23:48:41.908067 [ 30720 ] {42dd15c2-01d4-43b3-99e7-19546c6d348f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONArrayLength doesn't match: passed 3, should be 1: In scope SELECT JSONArrayLength(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:41.955211 [ 30720 ] {2f19f32e-b04b-46b7-aee6-a16778caf6b2} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONDynamicPaths doesn't match: passed 3, should be 1: In scope SELECT JSONDynamicPaths(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT JSONDynamicPaths(NULL, NULL, NULL);) 2025.10.23 23:48:41.959208 [ 30720 ] {2f19f32e-b04b-46b7-aee6-a16778caf6b2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONDynamicPaths doesn't match: passed 3, should be 1: In scope SELECT JSONDynamicPaths(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:42.006098 [ 30720 ] {503dc559-eb56-41d2-9400-c900fc1130b2} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONDynamicPathsWithTypes doesn't match: passed 3, should be 1: In scope SELECT JSONDynamicPathsWithTypes(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT JSONDynamicPathsWithTypes(NULL, NULL, NULL);) 2025.10.23 23:48:42.009728 [ 30720 ] {503dc559-eb56-41d2-9400-c900fc1130b2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONDynamicPathsWithTypes doesn't match: passed 3, should be 1: In scope SELECT JSONDynamicPathsWithTypes(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:42.056351 [ 30720 ] {f3831c5e-5159-41ee-8263-1667c51af57c} executeQuery: Code: 44. DB::Exception: The last argument of function JSONExtract should be a constant string specifying the return data type, illegal value: NULL: In scope SELECT JSONExtract(NULL, NULL, NULL). (ILLEGAL_COLUMN) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT JSONExtract(NULL, NULL, NULL);) 2025.10.23 23:48:42.059869 [ 30720 ] {f3831c5e-5159-41ee-8263-1667c51af57c} TCPHandler: Code: 44. DB::Exception: The last argument of function JSONExtract should be a constant string specifying the return data type, illegal value: NULL: In scope SELECT JSONExtract(NULL, NULL, NULL). (ILLEGAL_COLUMN) 2025.10.23 23:48:42.304852 [ 3414 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:42.305261 [ 3417 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:42.305503 [ 3410 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:42.445071 [ 3407 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:42.474365 [ 30720 ] {04ccfe29-9995-45c7-ae2d-0bae059644ef} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=748). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT JSONExtractKeys(NULL, NULL, NULL);) 2025.10.23 23:48:42.478494 [ 30720 ] {04ccfe29-9995-45c7-ae2d-0bae059644ef} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=748). (CANNOT_SCHEDULE_TASK) 2025.10.23 23:48:42.527861 [ 30720 ] {7cb30ed3-7428-4576-a51c-79f220b7e4cb} executeQuery: Code: 44. DB::Exception: The last argument of function JSONExtractKeysAndValues should be a constant string specifying the values' data type, illegal value: NULL: In scope SELECT JSONExtractKeysAndValues(NULL, NULL, NULL). (ILLEGAL_COLUMN) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT JSONExtractKeysAndValues(NULL, NULL, NULL);) 2025.10.23 23:48:42.531902 [ 30720 ] {7cb30ed3-7428-4576-a51c-79f220b7e4cb} TCPHandler: Code: 44. DB::Exception: The last argument of function JSONExtractKeysAndValues should be a constant string specifying the values' data type, illegal value: NULL: In scope SELECT JSONExtractKeysAndValues(NULL, NULL, NULL). (ILLEGAL_COLUMN) 2025.10.23 23:48:42.664248 [ 3399 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:42.721780 [ 3408 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:43.232551 [ 29264 ] {0f40f3f6-27fb-45c1-ab55-2d88baf874a4} executeQuery: Code: 632. DB::Exception: Invalid expression for function parseReadableSize - Found trailing characters after readable size string ("1 B leftovers"): In scope SELECT parseReadableSize('1 B leftovers'). (UNEXPECTED_DATA_AFTER_PARSED_VALUE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:52076) (comment: 03165_parseReadableSize.sql) (in query: -- Invalid input - Trailing characters SELECT parseReadableSize('1 B leftovers');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type>, String&&, std::basic_string_view> const&) @ 0x00000000086835ed 4. DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x0000000019c8d7c2 5. DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000019c8b9ca 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 2025.10.23 23:48:43.233960 [ 29264 ] {0f40f3f6-27fb-45c1-ab55-2d88baf874a4} TCPHandler: Code: 632. DB::Exception: Invalid expression for function parseReadableSize - Found trailing characters after readable size string ("1 B leftovers"): In scope SELECT parseReadableSize('1 B leftovers'). (UNEXPECTED_DATA_AFTER_PARSED_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type>, String&&, std::basic_string_view> const&) @ 0x00000000086835ed 4. DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x0000000019c8d7c2 5. DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000019c8b9ca 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 2025.10.23 23:48:43.305619 [ 3369 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:43.306290 [ 3367 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:43.306452 [ 3370 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:43.403682 [ 30720 ] {331e5d68-6d84-4c34-b0fd-f2cb2082b9f4} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONSharedDataPaths doesn't match: passed 3, should be 1: In scope SELECT JSONSharedDataPaths(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT JSONSharedDataPaths(NULL, NULL, NULL);) 2025.10.23 23:48:43.406089 [ 30720 ] {331e5d68-6d84-4c34-b0fd-f2cb2082b9f4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONSharedDataPaths doesn't match: passed 3, should be 1: In scope SELECT JSONSharedDataPaths(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:43.446242 [ 3382 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:43.531979 [ 30720 ] {3477b5c4-edfa-47c8-a8cd-688de28650ea} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONSharedDataPathsWithTypes doesn't match: passed 3, should be 1: In scope SELECT JSONSharedDataPathsWithTypes(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT JSONSharedDataPathsWithTypes(NULL, NULL, NULL);) 2025.10.23 23:48:43.534606 [ 30720 ] {3477b5c4-edfa-47c8-a8cd-688de28650ea} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONSharedDataPathsWithTypes doesn't match: passed 3, should be 1: In scope SELECT JSONSharedDataPathsWithTypes(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:43.665195 [ 3364 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:43.720819 [ 30720 ] {5842a3aa-e6da-45df-8be3-349d024ca5ff} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONArrayLength doesn't match: passed 3, should be 1: In scope SELECT JSON_ARRAY_LENGTH(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT JSON_ARRAY_LENGTH(NULL, NULL, NULL);) 2025.10.23 23:48:43.722959 [ 3361 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:43.724468 [ 30720 ] {5842a3aa-e6da-45df-8be3-349d024ca5ff} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONArrayLength doesn't match: passed 3, should be 1: In scope SELECT JSON_ARRAY_LENGTH(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:44.113223 [ 30720 ] {363ea19c-aca9-4dc3-80ce-b7540bd59cee} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Distance doesn't match: passed 3, should be 2: In scope SELECT L1Distance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT L1Distance(NULL, NULL, NULL);) 2025.10.23 23:48:44.115974 [ 30720 ] {363ea19c-aca9-4dc3-80ce-b7540bd59cee} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Distance doesn't match: passed 3, should be 2: In scope SELECT L1Distance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:44.146452 [ 30720 ] {61624409-fc64-466d-b28f-7284729daa62} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Norm doesn't match: passed 3, should be 1: In scope SELECT L1Norm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT L1Norm(NULL, NULL, NULL);) 2025.10.23 23:48:44.172319 [ 30720 ] {61624409-fc64-466d-b28f-7284729daa62} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Norm doesn't match: passed 3, should be 1: In scope SELECT L1Norm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:44.224215 [ 30720 ] {b313c2ae-7233-4c96-96ca-da8b06226738} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Normalize doesn't match: passed 3, should be 1: In scope SELECT L1Normalize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT L1Normalize(NULL, NULL, NULL);) 2025.10.23 23:48:44.227085 [ 30720 ] {b313c2ae-7233-4c96-96ca-da8b06226738} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Normalize doesn't match: passed 3, should be 1: In scope SELECT L1Normalize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:44.256852 [ 30720 ] {6e8ad67d-63e4-4260-ae23-dbc3dbdcce0d} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Distance doesn't match: passed 3, should be 2: In scope SELECT L2Distance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT L2Distance(NULL, NULL, NULL);) 2025.10.23 23:48:44.259276 [ 30720 ] {6e8ad67d-63e4-4260-ae23-dbc3dbdcce0d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Distance doesn't match: passed 3, should be 2: In scope SELECT L2Distance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:44.306681 [ 3337 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:44.307365 [ 3350 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:44.308026 [ 3337 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:44.378114 [ 30720 ] {93554ad8-8796-46b1-aae1-daacf7559c39} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Norm doesn't match: passed 3, should be 1: In scope SELECT L2Norm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT L2Norm(NULL, NULL, NULL);) 2025.10.23 23:48:44.380815 [ 30720 ] {93554ad8-8796-46b1-aae1-daacf7559c39} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Norm doesn't match: passed 3, should be 1: In scope SELECT L2Norm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:44.409226 [ 30720 ] {7e87a236-0078-4bd3-a63a-4451207b36ae} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Normalize doesn't match: passed 3, should be 1: In scope SELECT L2Normalize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT L2Normalize(NULL, NULL, NULL);) 2025.10.23 23:48:44.411660 [ 30720 ] {7e87a236-0078-4bd3-a63a-4451207b36ae} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Normalize doesn't match: passed 3, should be 1: In scope SELECT L2Normalize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:44.447599 [ 3355 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:44.490794 [ 30720 ] {4d070c67-faa0-49bd-a722-923e984d9aaf} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2SquaredDistance doesn't match: passed 3, should be 2: In scope SELECT L2SquaredDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT L2SquaredDistance(NULL, NULL, NULL);) 2025.10.23 23:48:44.494734 [ 30720 ] {4d070c67-faa0-49bd-a722-923e984d9aaf} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2SquaredDistance doesn't match: passed 3, should be 2: In scope SELECT L2SquaredDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:44.530737 [ 30720 ] {f1424f50-1f18-4c37-9d3d-8cd510feb94e} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2SquaredNorm doesn't match: passed 3, should be 1: In scope SELECT L2SquaredNorm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT L2SquaredNorm(NULL, NULL, NULL);) 2025.10.23 23:48:44.534629 [ 30720 ] {f1424f50-1f18-4c37-9d3d-8cd510feb94e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2SquaredNorm doesn't match: passed 3, should be 1: In scope SELECT L2SquaredNorm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:44.666279 [ 3328 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:44.724484 [ 3356 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:44.793519 [ 30720 ] {69171425-71ce-47c9-a0bb-5cd198c2d4e8} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfDistance doesn't match: passed 3, should be 2: In scope SELECT LinfDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT LinfDistance(NULL, NULL, NULL);) 2025.10.23 23:48:44.797327 [ 30720 ] {69171425-71ce-47c9-a0bb-5cd198c2d4e8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfDistance doesn't match: passed 3, should be 2: In scope SELECT LinfDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:44.884397 [ 30720 ] {603cd9c5-f924-4caf-b4fb-26a2ed312452} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfNorm doesn't match: passed 3, should be 1: In scope SELECT LinfNorm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT LinfNorm(NULL, NULL, NULL);) 2025.10.23 23:48:44.888093 [ 30720 ] {603cd9c5-f924-4caf-b4fb-26a2ed312452} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfNorm doesn't match: passed 3, should be 1: In scope SELECT LinfNorm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:44.934522 [ 30720 ] {a943ae23-6929-4e5a-918e-3331c52453a3} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfNormalize doesn't match: passed 3, should be 1: In scope SELECT LinfNormalize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT LinfNormalize(NULL, NULL, NULL);) 2025.10.23 23:48:45.016398 [ 30720 ] {a943ae23-6929-4e5a-918e-3331c52453a3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfNormalize doesn't match: passed 3, should be 1: In scope SELECT LinfNormalize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:45.235015 [ 30720 ] {03621445-4210-4cb2-bfe4-a6754fbb5ef2} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpNorm doesn't match: passed 3, should be 2: In scope SELECT LpNorm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT LpNorm(NULL, NULL, NULL);) 2025.10.23 23:48:45.268723 [ 30720 ] {03621445-4210-4cb2-bfe4-a6754fbb5ef2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpNorm doesn't match: passed 3, should be 2: In scope SELECT LpNorm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:45.305738 [ 30720 ] {5fd27cb2-5ad5-4adb-b2e4-a99cc6d99a0c} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpNormalize doesn't match: passed 3, should be 2: In scope SELECT LpNormalize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT LpNormalize(NULL, NULL, NULL);) 2025.10.23 23:48:45.308048 [ 3307 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:45.308828 [ 3304 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:45.309387 [ 3310 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:45.310350 [ 30720 ] {5fd27cb2-5ad5-4adb-b2e4-a99cc6d99a0c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpNormalize doesn't match: passed 3, should be 2: In scope SELECT LpNormalize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:45.345925 [ 30720 ] {1853823c-4541-4a59-a6fb-38f386e10356} executeQuery: Code: 42. DB::Exception: Number of arguments for function MACNumToString doesn't match: passed 3, should be 1: In scope SELECT MACNumToString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT MACNumToString(NULL, NULL, NULL);) 2025.10.23 23:48:45.349035 [ 30720 ] {1853823c-4541-4a59-a6fb-38f386e10356} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MACNumToString doesn't match: passed 3, should be 1: In scope SELECT MACNumToString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:45.449287 [ 3305 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:45.451537 [ 30720 ] {9910c16d-6d40-4801-acb6-39d657458c3d} executeQuery: Code: 42. DB::Exception: Number of arguments for function MACStringToNum doesn't match: passed 3, should be 1: In scope SELECT MACStringToNum(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT MACStringToNum(NULL, NULL, NULL);) 2025.10.23 23:48:45.535662 [ 30720 ] {9910c16d-6d40-4801-acb6-39d657458c3d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MACStringToNum doesn't match: passed 3, should be 1: In scope SELECT MACStringToNum(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:45.667274 [ 3298 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:45.725863 [ 3308 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:45.761401 [ 30720 ] {a4339397-42e5-4691-a42c-dc562a5af7ac} executeQuery: Code: 42. DB::Exception: Number of arguments for function MACStringToOUI doesn't match: passed 3, should be 1: In scope SELECT MACStringToOUI(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT MACStringToOUI(NULL, NULL, NULL);) 2025.10.23 23:48:45.765410 [ 30720 ] {a4339397-42e5-4691-a42c-dc562a5af7ac} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MACStringToOUI doesn't match: passed 3, should be 1: In scope SELECT MACStringToOUI(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:45.886321 [ 30720 ] {ca8b7b8f-91a6-4687-a14d-17ee42044563} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapFromArrays doesn't match: passed 3, should be 2: In scope SELECT MAP_FROM_ARRAYS(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT MAP_FROM_ARRAYS(NULL, NULL, NULL);) 2025.10.23 23:48:45.890125 [ 30720 ] {ca8b7b8f-91a6-4687-a14d-17ee42044563} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapFromArrays doesn't match: passed 3, should be 2: In scope SELECT MAP_FROM_ARRAYS(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:45.979376 [ 30720 ] {e10f3b75-c8f4-4d6a-a4b1-1b446899e981} executeQuery: Code: 42. DB::Exception: Number of arguments for function MD4 doesn't match: passed 3, should be 1: In scope SELECT MD4(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT MD4(NULL, NULL, NULL);) 2025.10.23 23:48:45.983002 [ 30720 ] {e10f3b75-c8f4-4d6a-a4b1-1b446899e981} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MD4 doesn't match: passed 3, should be 1: In scope SELECT MD4(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:46.030263 [ 30720 ] {075d597a-6db3-4b3c-aeb2-fc115530a617} executeQuery: Code: 42. DB::Exception: Number of arguments for function MD5 doesn't match: passed 3, should be 1: In scope SELECT MD5(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT MD5(NULL, NULL, NULL);) 2025.10.23 23:48:46.033943 [ 30720 ] {075d597a-6db3-4b3c-aeb2-fc115530a617} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MD5 doesn't match: passed 3, should be 1: In scope SELECT MD5(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:46.309031 [ 3278 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:46.309877 [ 3283 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:46.310549 [ 3282 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:46.321283 [ 29264 ] {95e9afe9-59ab-4533-9a60-c22d1f3f6180} executeQuery: Code: 36. DB::Exception: Invalid expression for function parseReadableSize - Negative sizes are not allowed (-1): In scope SELECT parseReadableSize('-1 KiB'). (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:52076) (comment: 03165_parseReadableSize.sql) (in query: -- Invalid input - Negative sizes are not allowed SELECT parseReadableSize('-1 KiB');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x0000000019c8ebad 4. DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x0000000019c8e04a 5. DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000019c8b9ca 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 2025.10.23 23:48:46.323155 [ 29264 ] {95e9afe9-59ab-4533-9a60-c22d1f3f6180} TCPHandler: Code: 36. DB::Exception: Invalid expression for function parseReadableSize - Negative sizes are not allowed (-1): In scope SELECT parseReadableSize('-1 KiB'). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x0000000019c8ebad 4. DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x0000000019c8e04a 5. DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000019c8b9ca 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 2025.10.23 23:48:46.438202 [ 30720 ] {3b7e62d3-d9c9-4a66-8c4a-46f6e3f08fd9} executeQuery: Code: 42. DB::Exception: Number of arguments for function length doesn't match: passed 3, should be 1: In scope SELECT OCTET_LENGTH(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT OCTET_LENGTH(NULL, NULL, NULL);) 2025.10.23 23:48:46.441941 [ 30720 ] {3b7e62d3-d9c9-4a66-8c4a-46f6e3f08fd9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function length doesn't match: passed 3, should be 1: In scope SELECT OCTET_LENGTH(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:46.450669 [ 3280 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:46.668374 [ 3276 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:46.723786 [ 30720 ] {24481121-dd92-48ac-aeba-988ffdb3942a} executeQuery: Code: 42. DB::Exception: Number of arguments for function match doesn't match: passed 3, should be 2: In scope SELECT REGEXP_MATCHES(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT REGEXP_MATCHES(NULL, NULL, NULL);) 2025.10.23 23:48:46.727020 [ 30720 ] {24481121-dd92-48ac-aeba-988ffdb3942a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function match doesn't match: passed 3, should be 2: In scope SELECT REGEXP_MATCHES(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:46.727271 [ 3270 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:46.822363 [ 30720 ] {2e3a0f0e-9247-4ef7-a3a2-88193306a05e} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 3, should be 0: In scope SELECT SCHEMA(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT SCHEMA(NULL, NULL, NULL);) 2025.10.23 23:48:46.825364 [ 30720 ] {2e3a0f0e-9247-4ef7-a3a2-88193306a05e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 3, should be 0: In scope SELECT SCHEMA(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:46.936648 [ 30720 ] {a8e6fad1-3e4b-4cd2-bfd7-c362aea6fbc9} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA1 doesn't match: passed 3, should be 1: In scope SELECT SHA1(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT SHA1(NULL, NULL, NULL);) 2025.10.23 23:48:46.939125 [ 30720 ] {a8e6fad1-3e4b-4cd2-bfd7-c362aea6fbc9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA1 doesn't match: passed 3, should be 1: In scope SELECT SHA1(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:46.978115 [ 30720 ] {813b6216-99f5-454d-99f7-a2d984951a22} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA224 doesn't match: passed 3, should be 1: In scope SELECT SHA224(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT SHA224(NULL, NULL, NULL);) 2025.10.23 23:48:46.980770 [ 30720 ] {813b6216-99f5-454d-99f7-a2d984951a22} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA224 doesn't match: passed 3, should be 1: In scope SELECT SHA224(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:47.032227 [ 30720 ] {f4b402bf-cb58-4367-86fb-1371fea56d6e} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA256 doesn't match: passed 3, should be 1: In scope SELECT SHA256(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT SHA256(NULL, NULL, NULL);) 2025.10.23 23:48:47.036666 [ 30720 ] {f4b402bf-cb58-4367-86fb-1371fea56d6e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA256 doesn't match: passed 3, should be 1: In scope SELECT SHA256(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:47.066899 [ 30720 ] {21207997-9fc8-46d9-929f-e3c6fdb3c521} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA384 doesn't match: passed 3, should be 1: In scope SELECT SHA384(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT SHA384(NULL, NULL, NULL);) 2025.10.23 23:48:47.069494 [ 30720 ] {21207997-9fc8-46d9-929f-e3c6fdb3c521} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA384 doesn't match: passed 3, should be 1: In scope SELECT SHA384(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:47.094878 [ 30720 ] {87e06332-d507-4d51-9c6f-10780208afbe} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA512 doesn't match: passed 3, should be 1: In scope SELECT SHA512(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT SHA512(NULL, NULL, NULL);) 2025.10.23 23:48:47.097197 [ 30720 ] {87e06332-d507-4d51-9c6f-10780208afbe} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA512 doesn't match: passed 3, should be 1: In scope SELECT SHA512(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:47.129029 [ 30720 ] {66e789f2-f761-42eb-a185-d8679c83e01b} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA512_256 doesn't match: passed 3, should be 1: In scope SELECT SHA512_256(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT SHA512_256(NULL, NULL, NULL);) 2025.10.23 23:48:47.131818 [ 30720 ] {66e789f2-f761-42eb-a185-d8679c83e01b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA512_256 doesn't match: passed 3, should be 1: In scope SELECT SHA512_256(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:47.310307 [ 3246 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:47.310964 [ 3243 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:47.311660 [ 3248 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:47.452336 [ 3240 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:47.669419 [ 3233 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:47.728883 [ 3241 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:48.251476 [ 30720 ] {0b690d84-e1ef-4f20-897d-bc693ed33a2c} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64Encode doesn't match: passed 3, should be 1: In scope SELECT TO_BASE64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT TO_BASE64(NULL, NULL, NULL);) 2025.10.23 23:48:48.255292 [ 30720 ] {0b690d84-e1ef-4f20-897d-bc693ed33a2c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64Encode doesn't match: passed 3, should be 1: In scope SELECT TO_BASE64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:48.311659 [ 3212 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:48.312267 [ 3225 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:48.313305 [ 3209 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:48.453745 [ 3210 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:48.639284 [ 30720 ] {8ca7065a-412e-452c-9656-f0b575f7ccab} executeQuery: Code: 42. DB::Exception: Number of arguments for function URLHierarchy doesn't match: passed 3, should be 1: In scope SELECT URLHierarchy(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT URLHierarchy(NULL, NULL, NULL);) 2025.10.23 23:48:48.643042 [ 30720 ] {8ca7065a-412e-452c-9656-f0b575f7ccab} TCPHandler: Code: 42. DB::Exception: Number of arguments for function URLHierarchy doesn't match: passed 3, should be 1: In scope SELECT URLHierarchy(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:48.670658 [ 3194 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:48.691183 [ 30720 ] {5b979076-735a-4bb3-a7e6-61632f7bfd0c} executeQuery: Code: 42. DB::Exception: Number of arguments for function URLPathHierarchy doesn't match: passed 3, should be 1: In scope SELECT URLPathHierarchy(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT URLPathHierarchy(NULL, NULL, NULL);) 2025.10.23 23:48:48.694953 [ 30720 ] {5b979076-735a-4bb3-a7e6-61632f7bfd0c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function URLPathHierarchy doesn't match: passed 3, should be 1: In scope SELECT URLPathHierarchy(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:48.730027 [ 3189 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:48.740752 [ 30720 ] {38b32ff2-65f1-4253-9a47-0d193bc92282} executeQuery: Code: 42. DB::Exception: Number of arguments for function UTCTimestamp doesn't match: passed 3, should be 0: In scope SELECT UTCTimestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT UTCTimestamp(NULL, NULL, NULL);) 2025.10.23 23:48:48.744523 [ 30720 ] {38b32ff2-65f1-4253-9a47-0d193bc92282} TCPHandler: Code: 42. DB::Exception: Number of arguments for function UTCTimestamp doesn't match: passed 3, should be 0: In scope SELECT UTCTimestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:48.790979 [ 30720 ] {f4656200-7fc9-44ec-8d3b-3b327cd90e04} executeQuery: Code: 42. DB::Exception: Number of arguments for function UTCTimestamp doesn't match: passed 3, should be 0: In scope SELECT UTC_timestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT UTC_timestamp(NULL, NULL, NULL);) 2025.10.23 23:48:48.794547 [ 30720 ] {f4656200-7fc9-44ec-8d3b-3b327cd90e04} TCPHandler: Code: 42. DB::Exception: Number of arguments for function UTCTimestamp doesn't match: passed 3, should be 0: In scope SELECT UTC_timestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:48.853511 [ 29264 ] {713cf200-5ccf-4905-8555-fd804ac29161} executeQuery: Code: 36. DB::Exception: Invalid expression for function parseReadableSize - Result is too big for output type ("1.152921504606847e+21"): In scope SELECT parseReadableSize('1000 EiB'). (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:52076) (comment: 03165_parseReadableSize.sql) (in query: -- Invalid input - Input too large to fit in UInt64 SELECT parseReadableSize('1000 EiB');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x0000000019c8ebad 4. DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x0000000019c8e420 5. DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000019c8b9ca 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 2025.10.23 23:48:48.856121 [ 29264 ] {713cf200-5ccf-4905-8555-fd804ac29161} TCPHandler: Code: 36. DB::Exception: Invalid expression for function parseReadableSize - Result is too big for output type ("1.152921504606847e+21"): In scope SELECT parseReadableSize('1000 EiB'). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x0000000019c8ebad 4. DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x0000000019c8e420 5. DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000019c8b9ca 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 2025.10.23 23:48:48.914851 [ 29264 ] {a8e71549-42c7-41b8-bd1c-22cd4e2bac50} executeQuery: Code: 6. DB::Exception: Invalid expression for function parseReadableSize - Unknown readable size unit ("xa123"): In scope SELECT parseReadableSize('0xa123 KiB'). (CANNOT_PARSE_TEXT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:52076) (comment: 03165_parseReadableSize.sql) (in query: -- Invalid input - Hexadecimal is not supported SELECT parseReadableSize('0xa123 KiB');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000df2a32d 4. DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x0000000019c8e230 5. DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000019c8b9ca 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 2025.10.23 23:48:48.916795 [ 29264 ] {a8e71549-42c7-41b8-bd1c-22cd4e2bac50} TCPHandler: Code: 6. DB::Exception: Invalid expression for function parseReadableSize - Unknown readable size unit ("xa123"): In scope SELECT parseReadableSize('0xa123 KiB'). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000df2a32d 4. DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x0000000019c8e230 5. DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000019c8b9ca 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 2025.10.23 23:48:49.313307 [ 3172 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:49.313335 [ 3178 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:49.314463 [ 3171 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:49.454968 [ 3167 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:49.672086 [ 3148 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:49.730999 [ 3161 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:49.838913 [ 30720 ] {b607fa37-09ef-4ab1-896a-7bf213d9e632} executeQuery: Code: 42. DB::Exception: Number of arguments for function _CAST doesn't match: passed 3, should be 2: In scope SELECT _CAST(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT _CAST(NULL, NULL, NULL);) 2025.10.23 23:48:49.841616 [ 30720 ] {b607fa37-09ef-4ab1-896a-7bf213d9e632} TCPHandler: Code: 42. DB::Exception: Number of arguments for function _CAST doesn't match: passed 3, should be 2: In scope SELECT _CAST(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:49.884853 [ 30720 ] {6d490128-911a-46ef-bca5-c96f7a410c55} executeQuery: Code: 42. DB::Exception: Number of arguments for function __actionName doesn't match: passed 3, should be 2: In scope SELECT __actionName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT __actionName(NULL, NULL, NULL);) 2025.10.23 23:48:49.888329 [ 30720 ] {6d490128-911a-46ef-bca5-c96f7a410c55} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __actionName doesn't match: passed 3, should be 2: In scope SELECT __actionName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:49.928868 [ 30720 ] {4e575c42-f228-467d-a743-ebb1852fe0b5} executeQuery: Code: 42. DB::Exception: Number of arguments for function __bitBoolMaskAnd doesn't match: passed 3, should be 2: In scope SELECT __bitBoolMaskAnd(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT __bitBoolMaskAnd(NULL, NULL, NULL);) 2025.10.23 23:48:49.931105 [ 30720 ] {4e575c42-f228-467d-a743-ebb1852fe0b5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __bitBoolMaskAnd doesn't match: passed 3, should be 2: In scope SELECT __bitBoolMaskAnd(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:49.971591 [ 30720 ] {d24d0a4e-37cc-4424-800c-a362715c6142} executeQuery: Code: 42. DB::Exception: Number of arguments for function __bitBoolMaskOr doesn't match: passed 3, should be 2: In scope SELECT __bitBoolMaskOr(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT __bitBoolMaskOr(NULL, NULL, NULL);) 2025.10.23 23:48:49.974158 [ 30720 ] {d24d0a4e-37cc-4424-800c-a362715c6142} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __bitBoolMaskOr doesn't match: passed 3, should be 2: In scope SELECT __bitBoolMaskOr(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:50.014360 [ 30720 ] {668e9dbf-0abe-4868-a4eb-adc57a81f98c} executeQuery: Code: 42. DB::Exception: Number of arguments for function __bitSwapLastTwo doesn't match: passed 3, should be 1: In scope SELECT __bitSwapLastTwo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT __bitSwapLastTwo(NULL, NULL, NULL);) 2025.10.23 23:48:50.016817 [ 30720 ] {668e9dbf-0abe-4868-a4eb-adc57a81f98c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __bitSwapLastTwo doesn't match: passed 3, should be 1: In scope SELECT __bitSwapLastTwo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:50.127238 [ 30720 ] {d810f9a6-66dd-4b4c-82f5-420371d29764} executeQuery: Code: 42. DB::Exception: Number of arguments for function __bitWrapperFunc doesn't match: passed 3, should be 1: In scope SELECT __bitWrapperFunc(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT __bitWrapperFunc(NULL, NULL, NULL);) 2025.10.23 23:48:50.129952 [ 30720 ] {d810f9a6-66dd-4b4c-82f5-420371d29764} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __bitWrapperFunc doesn't match: passed 3, should be 1: In scope SELECT __bitWrapperFunc(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:50.239996 [ 30720 ] {28a642eb-9488-4da8-839d-491e42edf86b} executeQuery: Code: 42. DB::Exception: Number of arguments for function __getScalar doesn't match: passed 3, should be 1: In scope SELECT __getScalar(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT __getScalar(NULL, NULL, NULL);) 2025.10.23 23:48:50.242420 [ 30720 ] {28a642eb-9488-4da8-839d-491e42edf86b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __getScalar doesn't match: passed 3, should be 1: In scope SELECT __getScalar(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:50.314364 [ 3145 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:50.314626 [ 3138 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:50.315674 [ 3134 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:50.365221 [ 30720 ] {6b89713e-b370-4e30-945b-2ea88af25484} executeQuery: Code: 42. DB::Exception: Number of arguments for function __scalarSubqueryResult doesn't match: passed 3, should be 1: In scope SELECT __scalarSubqueryResult(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT __scalarSubqueryResult(NULL, NULL, NULL);) 2025.10.23 23:48:50.367975 [ 30720 ] {6b89713e-b370-4e30-945b-2ea88af25484} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __scalarSubqueryResult doesn't match: passed 3, should be 1: In scope SELECT __scalarSubqueryResult(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:50.400354 [ 30720 ] {7bd923cb-dff8-476e-a429-8f1e1e65b50b} executeQuery: Code: 42. DB::Exception: Number of arguments for function abs doesn't match: passed 3, should be 1: In scope SELECT abs(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT abs(NULL, NULL, NULL);) 2025.10.23 23:48:50.402758 [ 30720 ] {7bd923cb-dff8-476e-a429-8f1e1e65b50b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function abs doesn't match: passed 3, should be 1: In scope SELECT abs(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:50.442079 [ 30720 ] {b9e54441-b274-4ea2-8664-26d5379eb2f2} executeQuery: Code: 42. DB::Exception: Number of arguments for function accurateCast doesn't match: passed 3, should be 2: In scope SELECT accurateCast(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT accurateCast(NULL, NULL, NULL);) 2025.10.23 23:48:50.444887 [ 30720 ] {b9e54441-b274-4ea2-8664-26d5379eb2f2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function accurateCast doesn't match: passed 3, should be 2: In scope SELECT accurateCast(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:50.456255 [ 3137 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:50.483510 [ 30720 ] {0a24f5c0-6921-4f46-9d3f-695092001523} executeQuery: Code: 43. DB::Exception: Second argument to accurateCastOrDefault must be a constant string describing type. Actual Nullable(Nothing): In scope SELECT accurateCastOrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT accurateCastOrDefault(NULL, NULL, NULL);) 2025.10.23 23:48:50.486180 [ 30720 ] {0a24f5c0-6921-4f46-9d3f-695092001523} TCPHandler: Code: 43. DB::Exception: Second argument to accurateCastOrDefault must be a constant string describing type. Actual Nullable(Nothing): In scope SELECT accurateCastOrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:48:50.526222 [ 30720 ] {f8a90d2b-f8dc-422d-a995-42bc8574aa14} executeQuery: Code: 42. DB::Exception: Number of arguments for function accurateCastOrNull doesn't match: passed 3, should be 2: In scope SELECT accurateCastOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT accurateCastOrNull(NULL, NULL, NULL);) 2025.10.23 23:48:50.528784 [ 30720 ] {f8a90d2b-f8dc-422d-a995-42bc8574aa14} TCPHandler: Code: 42. DB::Exception: Number of arguments for function accurateCastOrNull doesn't match: passed 3, should be 2: In scope SELECT accurateCastOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:50.635054 [ 30720 ] {fabd3f07-9961-4116-8bdb-e0e1753ede2b} executeQuery: Code: 42. DB::Exception: Number of arguments for function acos doesn't match: passed 3, should be 1: In scope SELECT acos(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT acos(NULL, NULL, NULL);) 2025.10.23 23:48:50.638706 [ 30720 ] {fabd3f07-9961-4116-8bdb-e0e1753ede2b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function acos doesn't match: passed 3, should be 1: In scope SELECT acos(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:50.673377 [ 3128 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:50.685230 [ 30720 ] {46dd1bab-187a-485f-87cc-0ab6cd8fa0f2} executeQuery: Code: 42. DB::Exception: Number of arguments for function acosh doesn't match: passed 3, should be 1: In scope SELECT acosh(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT acosh(NULL, NULL, NULL);) 2025.10.23 23:48:50.689058 [ 30720 ] {46dd1bab-187a-485f-87cc-0ab6cd8fa0f2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function acosh doesn't match: passed 3, should be 1: In scope SELECT acosh(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:50.731885 [ 3121 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:50.733887 [ 30720 ] {3201d3e6-c6a6-4e5d-816c-c341943f40c8} executeQuery: Code: 42. DB::Exception: Number of arguments for function addDate doesn't match: passed 3, should be 2: In scope SELECT addDate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT addDate(NULL, NULL, NULL);) 2025.10.23 23:48:50.737044 [ 30720 ] {3201d3e6-c6a6-4e5d-816c-c341943f40c8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addDate doesn't match: passed 3, should be 2: In scope SELECT addDate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:50.906569 [ 29264 ] {69399800-f7cf-4768-b502-14acd30bedc8} executeQuery: Code: 36. DB::Exception: Invalid expression for function parseReadableSize - Invalid numeric component: nan: In scope SELECT parseReadableSize('nan KiB'). (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:52076) (comment: 03165_parseReadableSize.sql) (in query: -- Invalid input - NaN is not supported, with or without sign and with different capitalizations SELECT parseReadableSize('nan KiB');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x0000000019c8ebad 4. DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x0000000019c8de6a 5. DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000019c8b9ca 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 2025.10.23 23:48:50.908176 [ 29264 ] {69399800-f7cf-4768-b502-14acd30bedc8} TCPHandler: Code: 36. DB::Exception: Invalid expression for function parseReadableSize - Invalid numeric component: nan: In scope SELECT parseReadableSize('nan KiB'). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x0000000019c8ebad 4. DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x0000000019c8de6a 5. DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000019c8b9ca 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 2025.10.23 23:48:50.944799 [ 29264 ] {bae37844-5057-4078-b180-f418daee45fc} executeQuery: Code: 36. DB::Exception: Invalid expression for function parseReadableSize - Invalid numeric component: nan: In scope SELECT parseReadableSize('+nan KiB'). (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:52076) (comment: 03165_parseReadableSize.sql) (in query: SELECT parseReadableSize('+nan KiB');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x0000000019c8ebad 4. DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x0000000019c8de6a 5. DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000019c8b9ca 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 2025.10.23 23:48:50.946610 [ 29264 ] {bae37844-5057-4078-b180-f418daee45fc} TCPHandler: Code: 36. DB::Exception: Invalid expression for function parseReadableSize - Invalid numeric component: nan: In scope SELECT parseReadableSize('+nan KiB'). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x0000000019c8ebad 4. DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x0000000019c8de6a 5. DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000019c8b9ca 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 2025.10.23 23:48:50.951408 [ 30720 ] {9003ab46-ce54-49b7-b80d-ed3e5ec52401} executeQuery: Code: 42. DB::Exception: Number of arguments for function addInterval doesn't match: passed 3, should be 2: In scope SELECT addInterval(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT addInterval(NULL, NULL, NULL);) 2025.10.23 23:48:50.953734 [ 30720 ] {9003ab46-ce54-49b7-b80d-ed3e5ec52401} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addInterval doesn't match: passed 3, should be 2: In scope SELECT addInterval(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:50.963063 [ 29264 ] {2705800c-7108-4f0f-90c6-8fb6f2aa25cf} executeQuery: Code: 36. DB::Exception: Invalid expression for function parseReadableSize - Invalid numeric component: -nan: In scope SELECT parseReadableSize('-nan KiB'). (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:52076) (comment: 03165_parseReadableSize.sql) (in query: SELECT parseReadableSize('-nan KiB');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x0000000019c8ebad 4. DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x0000000019c8de6a 5. DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000019c8b9ca 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 2025.10.23 23:48:50.964871 [ 29264 ] {2705800c-7108-4f0f-90c6-8fb6f2aa25cf} TCPHandler: Code: 36. DB::Exception: Invalid expression for function parseReadableSize - Invalid numeric component: -nan: In scope SELECT parseReadableSize('-nan KiB'). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x0000000019c8ebad 4. DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x0000000019c8de6a 5. DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000019c8b9ca 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 2025.10.23 23:48:50.981133 [ 29264 ] {9e06c900-9148-4b35-9b42-9e963d0172da} executeQuery: Code: 36. DB::Exception: Invalid expression for function parseReadableSize - Invalid numeric component: nan: In scope SELECT parseReadableSize('NaN KiB'). (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:52076) (comment: 03165_parseReadableSize.sql) (in query: SELECT parseReadableSize('NaN KiB');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x0000000019c8ebad 4. DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x0000000019c8de6a 5. DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000019c8b9ca 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 2025.10.23 23:48:50.982391 [ 29264 ] {9e06c900-9148-4b35-9b42-9e963d0172da} TCPHandler: Code: 36. DB::Exception: Invalid expression for function parseReadableSize - Invalid numeric component: nan: In scope SELECT parseReadableSize('NaN KiB'). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x0000000019c8ebad 4. DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x0000000019c8de6a 5. DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000019c8b9ca 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 2025.10.23 23:48:50.996510 [ 29264 ] {1617f8a0-8952-4825-b1ea-3cde7943f08a} executeQuery: Code: 36. DB::Exception: Invalid expression for function parseReadableSize - Invalid numeric component: inf: In scope SELECT parseReadableSize('inf KiB'). (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:52076) (comment: 03165_parseReadableSize.sql) (in query: -- Invalid input - Infinite is not supported, with or without sign, in all its forms SELECT parseReadableSize('inf KiB');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x0000000019c8ebad 4. DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x0000000019c8de6a 5. DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000019c8b9ca 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 2025.10.23 23:48:50.997747 [ 29264 ] {1617f8a0-8952-4825-b1ea-3cde7943f08a} TCPHandler: Code: 36. DB::Exception: Invalid expression for function parseReadableSize - Invalid numeric component: inf: In scope SELECT parseReadableSize('inf KiB'). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x0000000019c8ebad 4. DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x0000000019c8de6a 5. DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000019c8b9ca 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 2025.10.23 23:48:51.012795 [ 29264 ] {c0e952f4-10de-40a7-8bc8-023b9c4983fa} executeQuery: Code: 36. DB::Exception: Invalid expression for function parseReadableSize - Invalid numeric component: inf: In scope SELECT parseReadableSize('+inf KiB'). (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:52076) (comment: 03165_parseReadableSize.sql) (in query: SELECT parseReadableSize('+inf KiB');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x0000000019c8ebad 4. DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x0000000019c8de6a 5. DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000019c8b9ca 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 2025.10.23 23:48:51.014025 [ 29264 ] {c0e952f4-10de-40a7-8bc8-023b9c4983fa} TCPHandler: Code: 36. DB::Exception: Invalid expression for function parseReadableSize - Invalid numeric component: inf: In scope SELECT parseReadableSize('+inf KiB'). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x0000000019c8ebad 4. DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x0000000019c8de6a 5. DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000019c8b9ca 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 2025.10.23 23:48:51.029380 [ 29264 ] {001d84bc-329a-4868-af7a-a0db555f075d} executeQuery: Code: 36. DB::Exception: Invalid expression for function parseReadableSize - Invalid numeric component: -inf: In scope SELECT parseReadableSize('-inf KiB'). (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:52076) (comment: 03165_parseReadableSize.sql) (in query: SELECT parseReadableSize('-inf KiB');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x0000000019c8ebad 4. DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x0000000019c8de6a 5. DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000019c8b9ca 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 2025.10.23 23:48:51.030581 [ 29264 ] {001d84bc-329a-4868-af7a-a0db555f075d} TCPHandler: Code: 36. DB::Exception: Invalid expression for function parseReadableSize - Invalid numeric component: -inf: In scope SELECT parseReadableSize('-inf KiB'). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x0000000019c8ebad 4. DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x0000000019c8de6a 5. DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000019c8b9ca 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 2025.10.23 23:48:51.045287 [ 29264 ] {a45bfa56-70ee-4c02-a749-15275853bf92} executeQuery: Code: 36. DB::Exception: Invalid expression for function parseReadableSize - Invalid numeric component: inf: In scope SELECT parseReadableSize('infinite KiB'). (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:52076) (comment: 03165_parseReadableSize.sql) (in query: SELECT parseReadableSize('infinite KiB');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x0000000019c8ebad 4. DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x0000000019c8de6a 5. DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000019c8b9ca 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 2025.10.23 23:48:51.046574 [ 29264 ] {a45bfa56-70ee-4c02-a749-15275853bf92} TCPHandler: Code: 36. DB::Exception: Invalid expression for function parseReadableSize - Invalid numeric component: inf: In scope SELECT parseReadableSize('infinite KiB'). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x0000000019c8ebad 4. DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x0000000019c8de6a 5. DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000019c8b9ca 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 2025.10.23 23:48:51.060808 [ 29264 ] {bcb6f742-b0bc-4985-9eb3-6da0ff9a6fcf} executeQuery: Code: 36. DB::Exception: Invalid expression for function parseReadableSize - Invalid numeric component: inf: In scope SELECT parseReadableSize('+infinite KiB'). (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:52076) (comment: 03165_parseReadableSize.sql) (in query: SELECT parseReadableSize('+infinite KiB');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x0000000019c8ebad 4. DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x0000000019c8de6a 5. DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000019c8b9ca 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 2025.10.23 23:48:51.061939 [ 29264 ] {bcb6f742-b0bc-4985-9eb3-6da0ff9a6fcf} TCPHandler: Code: 36. DB::Exception: Invalid expression for function parseReadableSize - Invalid numeric component: inf: In scope SELECT parseReadableSize('+infinite KiB'). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x0000000019c8ebad 4. DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x0000000019c8de6a 5. DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000019c8b9ca 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 2025.10.23 23:48:51.075618 [ 29264 ] {2d2989f5-1636-4618-851f-1e5c43ee271b} executeQuery: Code: 36. DB::Exception: Invalid expression for function parseReadableSize - Invalid numeric component: -inf: In scope SELECT parseReadableSize('-infinite KiB'). (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:52076) (comment: 03165_parseReadableSize.sql) (in query: SELECT parseReadableSize('-infinite KiB');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x0000000019c8ebad 4. DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x0000000019c8de6a 5. DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000019c8b9ca 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 2025.10.23 23:48:51.076915 [ 29264 ] {2d2989f5-1636-4618-851f-1e5c43ee271b} TCPHandler: Code: 36. DB::Exception: Invalid expression for function parseReadableSize - Invalid numeric component: -inf: In scope SELECT parseReadableSize('-infinite KiB'). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x0000000019c8ebad 4. DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x0000000019c8de6a 5. DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000019c8b9ca 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 2025.10.23 23:48:51.090463 [ 29264 ] {02f5b9c5-2c38-436a-bda5-a042c0bc5e36} executeQuery: Code: 36. DB::Exception: Invalid expression for function parseReadableSize - Invalid numeric component: inf: In scope SELECT parseReadableSize('Inf KiB'). (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:52076) (comment: 03165_parseReadableSize.sql) (in query: SELECT parseReadableSize('Inf KiB');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x0000000019c8ebad 4. DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x0000000019c8de6a 5. DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000019c8b9ca 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 2025.10.23 23:48:51.091608 [ 29264 ] {02f5b9c5-2c38-436a-bda5-a042c0bc5e36} TCPHandler: Code: 36. DB::Exception: Invalid expression for function parseReadableSize - Invalid numeric component: inf: In scope SELECT parseReadableSize('Inf KiB'). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x0000000019c8ebad 4. DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x0000000019c8de6a 5. DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000019c8b9ca 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 2025.10.23 23:48:51.104987 [ 29264 ] {fc3cb56d-5410-4d3a-99a7-826cfdc6c23d} executeQuery: Code: 36. DB::Exception: Invalid expression for function parseReadableSize - Invalid numeric component: inf: In scope SELECT parseReadableSize('Infinite KiB'). (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:52076) (comment: 03165_parseReadableSize.sql) (in query: SELECT parseReadableSize('Infinite KiB');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x0000000019c8ebad 4. DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x0000000019c8de6a 5. DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000019c8b9ca 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 2025.10.23 23:48:51.106243 [ 29264 ] {fc3cb56d-5410-4d3a-99a7-826cfdc6c23d} TCPHandler: Code: 36. DB::Exception: Invalid expression for function parseReadableSize - Invalid numeric component: inf: In scope SELECT parseReadableSize('Infinite KiB'). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x0000000019c8ebad 4. DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x0000000019c8de6a 5. DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000019c8b9ca 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 2025.10.23 23:48:51.315433 [ 3131 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:51.316180 [ 3132 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:51.317064 [ 3120 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:51.457570 [ 3107 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:51.498870 [ 30720 ] {f7fadee0-7e4d-41ab-af19-a953348d1c8a} executeQuery: Code: 42. DB::Exception: Number of arguments for function addTupleOfIntervals doesn't match: passed 3, should be 2: In scope SELECT addTupleOfIntervals(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT addTupleOfIntervals(NULL, NULL, NULL);) 2025.10.23 23:48:51.503588 [ 30720 ] {f7fadee0-7e4d-41ab-af19-a953348d1c8a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addTupleOfIntervals doesn't match: passed 3, should be 2: In scope SELECT addTupleOfIntervals(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:51.674423 [ 3103 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:51.678518 [ 30720 ] {30dfda82-c595-4546-b9b5-1c12d889487b} executeQuery: Code: 42. DB::Exception: Number of arguments for function addressToLine doesn't match: passed 3, should be 1: In scope SELECT addressToLine(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT addressToLine(NULL, NULL, NULL);) 2025.10.23 23:48:51.682250 [ 30720 ] {30dfda82-c595-4546-b9b5-1c12d889487b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addressToLine doesn't match: passed 3, should be 1: In scope SELECT addressToLine(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:51.720100 [ 30720 ] {4fb95cf6-6562-4d2f-ba8b-2f3ba6256a49} executeQuery: Code: 42. DB::Exception: Number of arguments for function addressToLineWithInlines doesn't match: passed 3, should be 1: In scope SELECT addressToLineWithInlines(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT addressToLineWithInlines(NULL, NULL, NULL);) 2025.10.23 23:48:51.723506 [ 30720 ] {4fb95cf6-6562-4d2f-ba8b-2f3ba6256a49} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addressToLineWithInlines doesn't match: passed 3, should be 1: In scope SELECT addressToLineWithInlines(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:51.733012 [ 3097 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:51.759920 [ 30720 ] {5330993e-0272-47e8-a7df-efa0ccde40ae} executeQuery: Code: 42. DB::Exception: Number of arguments for function addressToSymbol doesn't match: passed 3, should be 1: In scope SELECT addressToSymbol(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT addressToSymbol(NULL, NULL, NULL);) 2025.10.23 23:48:51.763608 [ 30720 ] {5330993e-0272-47e8-a7df-efa0ccde40ae} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addressToSymbol doesn't match: passed 3, should be 1: In scope SELECT addressToSymbol(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:52.316811 [ 3092 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:52.317901 [ 3071 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:52.318355 [ 3082 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:52.459009 [ 3075 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:52.675333 [ 3080 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:52.734334 [ 3105 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:53.318068 [ 3444 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:53.318726 [ 3056 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:53.319394 [ 3060 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:53.372369 [ 30720 ] {9bd08af7-1c95-47e1-92c1-585c657f0f14} executeQuery: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT anyLast_respect_nulls(NULL, NULL, NULL);) 2025.10.23 23:48:53.374642 [ 30720 ] {9bd08af7-1c95-47e1-92c1-585c657f0f14} TCPHandler: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:53.460300 [ 3054 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:53.495785 [ 30720 ] {f574e089-3459-4478-8719-55afdbc71e62} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT any_respect_nulls(NULL, NULL, NULL);) 2025.10.23 23:48:53.498297 [ 30720 ] {f574e089-3459-4478-8719-55afdbc71e62} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:53.676522 [ 3345 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:53.735429 [ 3319 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:53.881026 [ 30720 ] {6ac15779-d4a6-4ec9-b336-045924dbcdf0} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT any_value_respect_nulls(NULL, NULL, NULL);) 2025.10.23 23:48:53.884840 [ 30720 ] {6ac15779-d4a6-4ec9-b336-045924dbcdf0} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:54.016111 [ 30720 ] {662af398-41ab-4383-8b3a-b0116be86be4} executeQuery: Code: 42. DB::Exception: Number of arguments for function appendTrailingCharIfAbsent doesn't match: passed 3, should be 2: In scope SELECT appendTrailingCharIfAbsent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT appendTrailingCharIfAbsent(NULL, NULL, NULL);) 2025.10.23 23:48:54.018648 [ 30720 ] {662af398-41ab-4383-8b3a-b0116be86be4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function appendTrailingCharIfAbsent doesn't match: passed 3, should be 2: In scope SELECT appendTrailingCharIfAbsent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:54.319157 [ 3197 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:54.319521 [ 3203 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:54.321797 [ 3168 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:54.461333 [ 3563 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:54.677310 [ 3557 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:54.736606 [ 3201 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:54.910810 [ 30720 ] {b4a7990a-f08b-4501-98bf-c4e2bd076cb9} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayAUC doesn't match: passed 3, should be 2: In scope SELECT arrayAUC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT arrayAUC(NULL, NULL, NULL);) 2025.10.23 23:48:54.914334 [ 30720 ] {b4a7990a-f08b-4501-98bf-c4e2bd076cb9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayAUC doesn't match: passed 3, should be 2: In scope SELECT arrayAUC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:55.320188 [ 3545 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:55.320299 [ 3532 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:55.322796 [ 3529 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:55.451020 [ 30720 ] {91ba9998-19f3-4a3a-9b2e-f885dab217d5} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayDistinct doesn't match: passed 3, should be 1: In scope SELECT arrayDistinct(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT arrayDistinct(NULL, NULL, NULL);) 2025.10.23 23:48:55.453642 [ 30720 ] {91ba9998-19f3-4a3a-9b2e-f885dab217d5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayDistinct doesn't match: passed 3, should be 1: In scope SELECT arrayDistinct(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:55.462726 [ 3528 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:55.491827 [ 30720 ] {1ca3443e-6d7f-4b11-b4a3-de5f96d89bd8} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayDotProduct doesn't match: passed 3, should be 2: In scope SELECT arrayDotProduct(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT arrayDotProduct(NULL, NULL, NULL);) 2025.10.23 23:48:55.494418 [ 30720 ] {1ca3443e-6d7f-4b11-b4a3-de5f96d89bd8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayDotProduct doesn't match: passed 3, should be 2: In scope SELECT arrayDotProduct(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:55.534238 [ 30720 ] {5089e957-4ebc-4e5e-9ace-250cce76faef} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayElement doesn't match: passed 3, should be 2: In scope SELECT arrayElement(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT arrayElement(NULL, NULL, NULL);) 2025.10.23 23:48:55.537462 [ 30720 ] {5089e957-4ebc-4e5e-9ace-250cce76faef} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayElement doesn't match: passed 3, should be 2: In scope SELECT arrayElement(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:55.614251 [ 30720 ] {cf849a2e-6c0e-4305-8375-8fd9227b831f} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayEnumerate doesn't match: passed 3, should be 1: In scope SELECT arrayEnumerate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT arrayEnumerate(NULL, NULL, NULL);) 2025.10.23 23:48:55.616971 [ 30720 ] {cf849a2e-6c0e-4305-8375-8fd9227b831f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayEnumerate doesn't match: passed 3, should be 1: In scope SELECT arrayEnumerate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:55.678398 [ 3549 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:55.737500 [ 3546 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:56.321295 [ 3508 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:56.321370 [ 3506 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:56.324051 [ 3505 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:56.381687 [ 30720 ] {1f51d152-7f3b-4a65-ad61-da3855d7a7ad} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayFlatten doesn't match: passed 3, should be 1: In scope SELECT arrayFlatten(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT arrayFlatten(NULL, NULL, NULL);) 2025.10.23 23:48:56.431422 [ 30720 ] {1f51d152-7f3b-4a65-ad61-da3855d7a7ad} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayFlatten doesn't match: passed 3, should be 1: In scope SELECT arrayFlatten(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:56.463878 [ 3513 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:56.542500 [ 30720 ] {b8e44eea-d758-4041-9cbd-9044baf1a18e} executeQuery: Code: 43. DB::Exception: First argument for function arrayFold must be a function: In scope SELECT arrayFold(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT arrayFold(NULL, NULL, NULL);) 2025.10.23 23:48:56.545787 [ 30720 ] {b8e44eea-d758-4041-9cbd-9044baf1a18e} TCPHandler: Code: 43. DB::Exception: First argument for function arrayFold must be a function: In scope SELECT arrayFold(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:48:56.662770 [ 30720 ] {6f767013-feba-4ad0-af13-8b55ddb90c0e} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayJaccardIndex doesn't match: passed 3, should be 2: In scope SELECT arrayJaccardIndex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT arrayJaccardIndex(NULL, NULL, NULL);) 2025.10.23 23:48:56.665269 [ 30720 ] {6f767013-feba-4ad0-af13-8b55ddb90c0e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayJaccardIndex doesn't match: passed 3, should be 2: In scope SELECT arrayJaccardIndex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:56.679555 [ 3496 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:56.704432 [ 30720 ] {f697a0d3-4fdf-4e06-9a03-5648ce06a8c2} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayJoin doesn't match: passed 3, should be 1: In scope SELECT arrayJoin(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT arrayJoin(NULL, NULL, NULL);) 2025.10.23 23:48:56.706963 [ 30720 ] {f697a0d3-4fdf-4e06-9a03-5648ce06a8c2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayJoin doesn't match: passed 3, should be 1: In scope SELECT arrayJoin(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:56.738600 [ 3494 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:57.322241 [ 3478 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:57.322241 [ 3512 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:57.324986 [ 3476 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:57.464709 [ 3490 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:57.680657 [ 3466 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:57.721487 [ 30720 ] {b0fb32da-aa8b-4be2-a42a-f7fa0a9fd935} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayPopBack doesn't match: passed 3, should be 1: In scope SELECT arrayPopBack(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT arrayPopBack(NULL, NULL, NULL);) 2025.10.23 23:48:57.724430 [ 30720 ] {b0fb32da-aa8b-4be2-a42a-f7fa0a9fd935} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayPopBack doesn't match: passed 3, should be 1: In scope SELECT arrayPopBack(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:57.740200 [ 3463 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:57.752744 [ 30720 ] {db6271ce-2987-4eb8-b802-e4f819778787} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayPopFront doesn't match: passed 3, should be 1: In scope SELECT arrayPopFront(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT arrayPopFront(NULL, NULL, NULL);) 2025.10.23 23:48:57.756047 [ 30720 ] {db6271ce-2987-4eb8-b802-e4f819778787} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayPopFront doesn't match: passed 3, should be 1: In scope SELECT arrayPopFront(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:57.915281 [ 30720 ] {56021f8e-269d-40fd-98a8-01575c796c72} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayPushBack doesn't match: passed 3, should be 2: In scope SELECT arrayPushBack(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT arrayPushBack(NULL, NULL, NULL);) 2025.10.23 23:48:57.918684 [ 30720 ] {56021f8e-269d-40fd-98a8-01575c796c72} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayPushBack doesn't match: passed 3, should be 2: In scope SELECT arrayPushBack(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:57.962560 [ 30720 ] {949e204e-7356-4a29-bd3c-f933f1053d04} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayPushFront doesn't match: passed 3, should be 2: In scope SELECT arrayPushFront(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT arrayPushFront(NULL, NULL, NULL);) 2025.10.23 23:48:57.966285 [ 30720 ] {949e204e-7356-4a29-bd3c-f933f1053d04} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayPushFront doesn't match: passed 3, should be 2: In scope SELECT arrayPushFront(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:58.008887 [ 30720 ] {6bc9c981-eb8c-42c0-9428-7e8d75ae46d4} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayRandomSample doesn't match: passed 3, should be 2: In scope SELECT arrayRandomSample(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT arrayRandomSample(NULL, NULL, NULL);) 2025.10.23 23:48:58.012152 [ 30720 ] {6bc9c981-eb8c-42c0-9428-7e8d75ae46d4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayRandomSample doesn't match: passed 3, should be 2: In scope SELECT arrayRandomSample(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:58.095408 [ 30720 ] {6e23b40b-a650-4bb2-84b4-d24c87803a33} executeQuery: Code: 43. DB::Exception: First argument for function arrayReduce must be constant string: name of aggregate function.: In scope SELECT arrayReduce(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT arrayReduce(NULL, NULL, NULL);) 2025.10.23 23:48:58.097773 [ 30720 ] {6e23b40b-a650-4bb2-84b4-d24c87803a33} TCPHandler: Code: 43. DB::Exception: First argument for function arrayReduce must be constant string: name of aggregate function.: In scope SELECT arrayReduce(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:48:58.204494 [ 30720 ] {f2493507-6863-4ed3-a180-18a795e47981} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayReverse doesn't match: passed 3, should be 1: In scope SELECT arrayReverse(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT arrayReverse(NULL, NULL, NULL);) 2025.10.23 23:48:58.207133 [ 30720 ] {f2493507-6863-4ed3-a180-18a795e47981} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayReverse doesn't match: passed 3, should be 1: In scope SELECT arrayReverse(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:58.323003 [ 3456 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:58.323007 [ 3446 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:58.325818 [ 3445 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:58.396166 [ 30720 ] {ed444e1e-842c-447d-b225-005607eca021} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayRotateLeft doesn't match: passed 3, should be 2: In scope SELECT arrayRotateLeft(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT arrayRotateLeft(NULL, NULL, NULL);) 2025.10.23 23:48:58.398614 [ 30720 ] {ed444e1e-842c-447d-b225-005607eca021} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayRotateLeft doesn't match: passed 3, should be 2: In scope SELECT arrayRotateLeft(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:58.427229 [ 30720 ] {3f7d5d53-84a4-45ac-9a3a-515eaccca102} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayRotateRight doesn't match: passed 3, should be 2: In scope SELECT arrayRotateRight(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT arrayRotateRight(NULL, NULL, NULL);) 2025.10.23 23:48:58.429761 [ 30720 ] {3f7d5d53-84a4-45ac-9a3a-515eaccca102} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayRotateRight doesn't match: passed 3, should be 2: In scope SELECT arrayRotateRight(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:58.465688 [ 3442 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:58.580272 [ 30720 ] {81db111f-ef62-47d9-b47e-a126eba56397} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayShingles doesn't match: passed 3, should be 2: In scope SELECT arrayShingles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT arrayShingles(NULL, NULL, NULL);) 2025.10.23 23:48:58.582742 [ 30720 ] {81db111f-ef62-47d9-b47e-a126eba56397} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayShingles doesn't match: passed 3, should be 2: In scope SELECT arrayShingles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:58.681474 [ 3533 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:58.741286 [ 3432 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:59.144602 [ 30720 ] {a85b01cd-64a2-45d7-851b-61caade44896} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayWithConstant doesn't match: passed 3, should be 2: In scope SELECT arrayWithConstant(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT arrayWithConstant(NULL, NULL, NULL);) 2025.10.23 23:48:59.148027 [ 30720 ] {a85b01cd-64a2-45d7-851b-61caade44896} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayWithConstant doesn't match: passed 3, should be 2: In scope SELECT arrayWithConstant(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:59.282095 [ 30720 ] {37d9eacc-2f70-4c7e-8d2e-353bceb1aab0} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT array_agg(NULL, NULL, NULL);) 2025.10.23 23:48:59.286116 [ 30720 ] {37d9eacc-2f70-4c7e-8d2e-353bceb1aab0} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) 2025.10.23 23:48:59.323997 [ 3417 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:59.324271 [ 3414 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:59.325432 [ 30720 ] {97bffa3d-91b5-4e4a-87aa-7c2dc0279808} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function with Array suffix. Must be array. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT array_concat_agg(NULL, NULL, NULL);) 2025.10.23 23:48:59.326577 [ 3410 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:59.328200 [ 30720 ] {97bffa3d-91b5-4e4a-87aa-7c2dc0279808} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function with Array suffix. Must be array. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:48:59.355955 [ 30720 ] {bf2273d2-d039-4ade-85e4-17ef063e53d5} executeQuery: Code: 42. DB::Exception: Number of arguments for function ascii doesn't match: passed 3, should be 1: In scope SELECT ascii(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT ascii(NULL, NULL, NULL);) 2025.10.23 23:48:59.359094 [ 30720 ] {bf2273d2-d039-4ade-85e4-17ef063e53d5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ascii doesn't match: passed 3, should be 1: In scope SELECT ascii(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:59.390353 [ 30720 ] {a77b5ffc-f875-4611-98ea-cffa61940d93} executeQuery: Code: 42. DB::Exception: Number of arguments for function asin doesn't match: passed 3, should be 1: In scope SELECT asin(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT asin(NULL, NULL, NULL);) 2025.10.23 23:48:59.467401 [ 3405 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:59.481635 [ 30720 ] {a77b5ffc-f875-4611-98ea-cffa61940d93} TCPHandler: Code: 42. DB::Exception: Number of arguments for function asin doesn't match: passed 3, should be 1: In scope SELECT asin(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:59.517664 [ 30720 ] {743e737f-375c-42c7-98b8-04a8452ffb77} executeQuery: Code: 42. DB::Exception: Number of arguments for function asinh doesn't match: passed 3, should be 1: In scope SELECT asinh(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT asinh(NULL, NULL, NULL);) 2025.10.23 23:48:59.521051 [ 30720 ] {743e737f-375c-42c7-98b8-04a8452ffb77} TCPHandler: Code: 42. DB::Exception: Number of arguments for function asinh doesn't match: passed 3, should be 1: In scope SELECT asinh(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:59.555153 [ 30720 ] {ee8f30db-dd99-452d-8c1a-e47c6bcae786} executeQuery: Code: 42. DB::Exception: Number of arguments for function assumeNotNull doesn't match: passed 3, should be 1: In scope SELECT assumeNotNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT assumeNotNull(NULL, NULL, NULL);) 2025.10.23 23:48:59.559247 [ 30720 ] {ee8f30db-dd99-452d-8c1a-e47c6bcae786} TCPHandler: Code: 42. DB::Exception: Number of arguments for function assumeNotNull doesn't match: passed 3, should be 1: In scope SELECT assumeNotNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:59.658305 [ 30720 ] {e77db263-a2a8-42d6-8b2f-d9983390d005} executeQuery: Code: 42. DB::Exception: Number of arguments for function atan doesn't match: passed 3, should be 1: In scope SELECT atan(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT atan(NULL, NULL, NULL);) 2025.10.23 23:48:59.662395 [ 30720 ] {e77db263-a2a8-42d6-8b2f-d9983390d005} TCPHandler: Code: 42. DB::Exception: Number of arguments for function atan doesn't match: passed 3, should be 1: In scope SELECT atan(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:59.682274 [ 3395 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:59.742434 [ 3397 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:59.751978 [ 30720 ] {800307cf-cd59-40b8-b3e1-bb4266694be2} executeQuery: Code: 42. DB::Exception: Number of arguments for function atan2 doesn't match: passed 3, should be 2: In scope SELECT atan2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT atan2(NULL, NULL, NULL);) 2025.10.23 23:48:59.755044 [ 30720 ] {800307cf-cd59-40b8-b3e1-bb4266694be2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function atan2 doesn't match: passed 3, should be 2: In scope SELECT atan2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:48:59.782957 [ 30720 ] {97fdf605-cee5-4bf3-ba93-907bec149d1e} executeQuery: Code: 42. DB::Exception: Number of arguments for function atanh doesn't match: passed 3, should be 1: In scope SELECT atanh(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT atanh(NULL, NULL, NULL);) 2025.10.23 23:48:59.785610 [ 30720 ] {97fdf605-cee5-4bf3-ba93-907bec149d1e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function atanh doesn't match: passed 3, should be 1: In scope SELECT atanh(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:00.128417 [ 30720 ] {3a270a6a-a307-4d51-bf98-60f5759dc3e1} executeQuery: Code: 42. DB::Exception: Number of arguments for function base58Decode doesn't match: passed 3, should be 1: In scope SELECT base58Decode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT base58Decode(NULL, NULL, NULL);) 2025.10.23 23:49:00.132433 [ 30720 ] {3a270a6a-a307-4d51-bf98-60f5759dc3e1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base58Decode doesn't match: passed 3, should be 1: In scope SELECT base58Decode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:00.161610 [ 30720 ] {6deb2354-85a7-4a11-81d8-0ed147fdabfa} executeQuery: Code: 42. DB::Exception: Number of arguments for function base58Encode doesn't match: passed 3, should be 1: In scope SELECT base58Encode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT base58Encode(NULL, NULL, NULL);) 2025.10.23 23:49:00.163927 [ 30720 ] {6deb2354-85a7-4a11-81d8-0ed147fdabfa} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base58Encode doesn't match: passed 3, should be 1: In scope SELECT base58Encode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:00.193767 [ 30720 ] {fe324173-0ce2-4e40-b5a0-e254796079f9} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64Decode doesn't match: passed 3, should be 1: In scope SELECT base64Decode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT base64Decode(NULL, NULL, NULL);) 2025.10.23 23:49:00.196640 [ 30720 ] {fe324173-0ce2-4e40-b5a0-e254796079f9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64Decode doesn't match: passed 3, should be 1: In scope SELECT base64Decode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:00.287385 [ 30720 ] {d5740074-098a-4e50-a531-3006d7e5491d} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64Encode doesn't match: passed 3, should be 1: In scope SELECT base64Encode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT base64Encode(NULL, NULL, NULL);) 2025.10.23 23:49:00.290255 [ 30720 ] {d5740074-098a-4e50-a531-3006d7e5491d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64Encode doesn't match: passed 3, should be 1: In scope SELECT base64Encode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:00.323203 [ 30720 ] {a9268834-75e3-4739-b1f1-986fd63f44b4} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64URLDecode doesn't match: passed 3, should be 1: In scope SELECT base64URLDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT base64URLDecode(NULL, NULL, NULL);) 2025.10.23 23:49:00.325201 [ 3378 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:00.325372 [ 3383 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:00.325991 [ 30720 ] {a9268834-75e3-4739-b1f1-986fd63f44b4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64URLDecode doesn't match: passed 3, should be 1: In scope SELECT base64URLDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:00.327673 [ 3375 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:00.354329 [ 30720 ] {82708bfd-6c19-4742-9957-bd8dc1e47ad1} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64URLEncode doesn't match: passed 3, should be 1: In scope SELECT base64URLEncode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT base64URLEncode(NULL, NULL, NULL);) 2025.10.23 23:49:00.356905 [ 30720 ] {82708bfd-6c19-4742-9957-bd8dc1e47ad1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64URLEncode doesn't match: passed 3, should be 1: In scope SELECT base64URLEncode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:00.385929 [ 30720 ] {1524e8ac-dc41-46e6-824c-bdd2541486a2} executeQuery: Code: 42. DB::Exception: Number of arguments for function basename doesn't match: passed 3, should be 1: In scope SELECT basename(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT basename(NULL, NULL, NULL);) 2025.10.23 23:49:00.389379 [ 30720 ] {1524e8ac-dc41-46e6-824c-bdd2541486a2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function basename doesn't match: passed 3, should be 1: In scope SELECT basename(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:00.422783 [ 30720 ] {6c077b98-8b98-4f70-ac5e-f1c40f8d263d} executeQuery: Code: 42. DB::Exception: Number of arguments for function bin doesn't match: passed 3, should be 1: In scope SELECT bin(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bin(NULL, NULL, NULL);) 2025.10.23 23:49:00.425713 [ 30720 ] {6c077b98-8b98-4f70-ac5e-f1c40f8d263d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bin doesn't match: passed 3, should be 1: In scope SELECT bin(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:00.458423 [ 30720 ] {33e314f8-f36a-47d5-bf08-bd992a528791} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitAnd doesn't match: passed 3, should be 2: In scope SELECT bitAnd(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitAnd(NULL, NULL, NULL);) 2025.10.23 23:49:00.461576 [ 30720 ] {33e314f8-f36a-47d5-bf08-bd992a528791} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitAnd doesn't match: passed 3, should be 2: In scope SELECT bitAnd(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:00.468560 [ 3367 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:00.490512 [ 30720 ] {e40f416a-0224-4b9f-b783-c0013004bb0a} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitCount doesn't match: passed 3, should be 1: In scope SELECT bitCount(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitCount(NULL, NULL, NULL);) 2025.10.23 23:49:00.493176 [ 30720 ] {e40f416a-0224-4b9f-b783-c0013004bb0a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitCount doesn't match: passed 3, should be 1: In scope SELECT bitCount(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:00.518343 [ 30720 ] {0e7ff9a9-01ff-458e-adc6-cc19d219b683} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitHammingDistance doesn't match: passed 3, should be 2: In scope SELECT bitHammingDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitHammingDistance(NULL, NULL, NULL);) 2025.10.23 23:49:00.520823 [ 30720 ] {0e7ff9a9-01ff-458e-adc6-cc19d219b683} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitHammingDistance doesn't match: passed 3, should be 2: In scope SELECT bitHammingDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:00.545390 [ 30720 ] {e89492c5-91c1-488f-9b0f-7c7ed3a9a306} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitNot doesn't match: passed 3, should be 1: In scope SELECT bitNot(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitNot(NULL, NULL, NULL);) 2025.10.23 23:49:00.547840 [ 30720 ] {e89492c5-91c1-488f-9b0f-7c7ed3a9a306} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitNot doesn't match: passed 3, should be 1: In scope SELECT bitNot(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:00.572795 [ 30720 ] {eb84bf1a-19c1-494d-9f15-3ec2c9cf730f} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitOr doesn't match: passed 3, should be 2: In scope SELECT bitOr(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitOr(NULL, NULL, NULL);) 2025.10.23 23:49:00.575398 [ 30720 ] {eb84bf1a-19c1-494d-9f15-3ec2c9cf730f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitOr doesn't match: passed 3, should be 2: In scope SELECT bitOr(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:00.602053 [ 30720 ] {4c0a4291-d45b-49b5-9083-e4e79e38e8e5} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitPositionsToArray doesn't match: passed 3, should be 1: In scope SELECT bitPositionsToArray(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitPositionsToArray(NULL, NULL, NULL);) 2025.10.23 23:49:00.604604 [ 30720 ] {4c0a4291-d45b-49b5-9083-e4e79e38e8e5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitPositionsToArray doesn't match: passed 3, should be 1: In scope SELECT bitPositionsToArray(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:00.631386 [ 30720 ] {621fbd12-2b20-45b3-bf9e-401fd81a31ee} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitRotateLeft doesn't match: passed 3, should be 2: In scope SELECT bitRotateLeft(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitRotateLeft(NULL, NULL, NULL);) 2025.10.23 23:49:00.633874 [ 30720 ] {621fbd12-2b20-45b3-bf9e-401fd81a31ee} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitRotateLeft doesn't match: passed 3, should be 2: In scope SELECT bitRotateLeft(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:00.662129 [ 30720 ] {a636b325-bb7b-4a1c-a663-012a4041dbba} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitRotateRight doesn't match: passed 3, should be 2: In scope SELECT bitRotateRight(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitRotateRight(NULL, NULL, NULL);) 2025.10.23 23:49:00.664774 [ 30720 ] {a636b325-bb7b-4a1c-a663-012a4041dbba} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitRotateRight doesn't match: passed 3, should be 2: In scope SELECT bitRotateRight(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:00.683367 [ 3385 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:00.693629 [ 30720 ] {a6c8663f-af5a-4d4b-a818-51564cb9c021} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitShiftLeft doesn't match: passed 3, should be 2: In scope SELECT bitShiftLeft(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitShiftLeft(NULL, NULL, NULL);) 2025.10.23 23:49:00.698466 [ 30720 ] {a6c8663f-af5a-4d4b-a818-51564cb9c021} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitShiftLeft doesn't match: passed 3, should be 2: In scope SELECT bitShiftLeft(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:00.728579 [ 30720 ] {35ca2229-84f3-4d67-b7df-00e8afbd8e45} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitShiftRight doesn't match: passed 3, should be 2: In scope SELECT bitShiftRight(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitShiftRight(NULL, NULL, NULL);) 2025.10.23 23:49:00.731137 [ 30720 ] {35ca2229-84f3-4d67-b7df-00e8afbd8e45} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitShiftRight doesn't match: passed 3, should be 2: In scope SELECT bitShiftRight(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:00.743523 [ 3374 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:00.883361 [ 30720 ] {47487ec4-5503-4f05-96f0-3ab63f5b8a9a} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitTest doesn't match: passed 3, should be 2: In scope SELECT bitTest(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitTest(NULL, NULL, NULL);) 2025.10.23 23:49:00.885842 [ 30720 ] {47487ec4-5503-4f05-96f0-3ab63f5b8a9a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitTest doesn't match: passed 3, should be 2: In scope SELECT bitTest(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:00.998539 [ 30720 ] {309cd7c1-434e-4752-813a-9175c12b3f49} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitXor doesn't match: passed 3, should be 2: In scope SELECT bitXor(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitXor(NULL, NULL, NULL);) 2025.10.23 23:49:01.001376 [ 30720 ] {309cd7c1-434e-4752-813a-9175c12b3f49} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitXor doesn't match: passed 3, should be 2: In scope SELECT bitXor(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:01.031918 [ 30720 ] {d2514cc9-7acf-4a8c-a417-3e8d11c4e80c} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapAnd doesn't match: passed 3, should be 2: In scope SELECT bitmapAnd(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitmapAnd(NULL, NULL, NULL);) 2025.10.23 23:49:01.034551 [ 30720 ] {d2514cc9-7acf-4a8c-a417-3e8d11c4e80c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapAnd doesn't match: passed 3, should be 2: In scope SELECT bitmapAnd(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:01.063992 [ 30720 ] {bc117535-42c3-4446-9188-fd8d2f9bfe09} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapAndCardinality doesn't match: passed 3, should be 2: In scope SELECT bitmapAndCardinality(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitmapAndCardinality(NULL, NULL, NULL);) 2025.10.23 23:49:01.066813 [ 30720 ] {bc117535-42c3-4446-9188-fd8d2f9bfe09} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapAndCardinality doesn't match: passed 3, should be 2: In scope SELECT bitmapAndCardinality(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:01.094278 [ 30720 ] {22cdb847-2ed5-42e2-94d2-10b1bc8cd65f} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapAndnot doesn't match: passed 3, should be 2: In scope SELECT bitmapAndnot(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitmapAndnot(NULL, NULL, NULL);) 2025.10.23 23:49:01.096482 [ 30720 ] {22cdb847-2ed5-42e2-94d2-10b1bc8cd65f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapAndnot doesn't match: passed 3, should be 2: In scope SELECT bitmapAndnot(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:01.122766 [ 30720 ] {6e3b191a-b32f-429c-9135-014fba019e47} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapAndnotCardinality doesn't match: passed 3, should be 2: In scope SELECT bitmapAndnotCardinality(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitmapAndnotCardinality(NULL, NULL, NULL);) 2025.10.23 23:49:01.125437 [ 30720 ] {6e3b191a-b32f-429c-9135-014fba019e47} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapAndnotCardinality doesn't match: passed 3, should be 2: In scope SELECT bitmapAndnotCardinality(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:01.155945 [ 30720 ] {ce6ae489-1291-43ac-9b2a-ad188eae699e} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapBuild doesn't match: passed 3, should be 1: In scope SELECT bitmapBuild(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitmapBuild(NULL, NULL, NULL);) 2025.10.23 23:49:01.158898 [ 30720 ] {ce6ae489-1291-43ac-9b2a-ad188eae699e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapBuild doesn't match: passed 3, should be 1: In scope SELECT bitmapBuild(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:01.284829 [ 30720 ] {171810a6-3073-4dec-99dd-c0b1be1c7e76} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapCardinality doesn't match: passed 3, should be 1: In scope SELECT bitmapCardinality(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitmapCardinality(NULL, NULL, NULL);) 2025.10.23 23:49:01.287299 [ 30720 ] {171810a6-3073-4dec-99dd-c0b1be1c7e76} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapCardinality doesn't match: passed 3, should be 1: In scope SELECT bitmapCardinality(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:01.315396 [ 30720 ] {df3ebf75-1f6f-4aa3-942d-9cb4696756a0} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapContains doesn't match: passed 3, should be 2: In scope SELECT bitmapContains(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitmapContains(NULL, NULL, NULL);) 2025.10.23 23:49:01.318001 [ 30720 ] {df3ebf75-1f6f-4aa3-942d-9cb4696756a0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapContains doesn't match: passed 3, should be 2: In scope SELECT bitmapContains(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:01.326121 [ 3352 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:01.326217 [ 3353 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:01.329080 [ 3346 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:01.356702 [ 30720 ] {0867db7a-ac5f-4a4d-86db-820bcaf57ce8} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapHasAll doesn't match: passed 3, should be 2: In scope SELECT bitmapHasAll(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitmapHasAll(NULL, NULL, NULL);) 2025.10.23 23:49:01.359243 [ 30720 ] {0867db7a-ac5f-4a4d-86db-820bcaf57ce8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapHasAll doesn't match: passed 3, should be 2: In scope SELECT bitmapHasAll(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:01.398230 [ 30720 ] {8b010f62-d4e2-4997-9126-693d12a67769} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapHasAny doesn't match: passed 3, should be 2: In scope SELECT bitmapHasAny(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitmapHasAny(NULL, NULL, NULL);) 2025.10.23 23:49:01.401271 [ 30720 ] {8b010f62-d4e2-4997-9126-693d12a67769} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapHasAny doesn't match: passed 3, should be 2: In scope SELECT bitmapHasAny(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:01.437121 [ 30720 ] {cdbcb145-58a3-4eff-9052-dbc563f99cb2} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapMax doesn't match: passed 3, should be 1: In scope SELECT bitmapMax(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitmapMax(NULL, NULL, NULL);) 2025.10.23 23:49:01.439668 [ 30720 ] {cdbcb145-58a3-4eff-9052-dbc563f99cb2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapMax doesn't match: passed 3, should be 1: In scope SELECT bitmapMax(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:01.469668 [ 3336 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:01.478694 [ 30720 ] {bea81b86-3e84-499d-becb-84440ec5edcf} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapMin doesn't match: passed 3, should be 1: In scope SELECT bitmapMin(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitmapMin(NULL, NULL, NULL);) 2025.10.23 23:49:01.481365 [ 30720 ] {bea81b86-3e84-499d-becb-84440ec5edcf} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapMin doesn't match: passed 3, should be 1: In scope SELECT bitmapMin(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:01.519590 [ 30720 ] {41c61388-87f7-4b18-bf0e-a035bfb342d2} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapOr doesn't match: passed 3, should be 2: In scope SELECT bitmapOr(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitmapOr(NULL, NULL, NULL);) 2025.10.23 23:49:01.525847 [ 30720 ] {41c61388-87f7-4b18-bf0e-a035bfb342d2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapOr doesn't match: passed 3, should be 2: In scope SELECT bitmapOr(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:01.566930 [ 30720 ] {ebb02bdf-9180-4ad1-b2fd-5cf1801022b4} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapOrCardinality doesn't match: passed 3, should be 2: In scope SELECT bitmapOrCardinality(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitmapOrCardinality(NULL, NULL, NULL);) 2025.10.23 23:49:01.570070 [ 30720 ] {ebb02bdf-9180-4ad1-b2fd-5cf1801022b4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapOrCardinality doesn't match: passed 3, should be 2: In scope SELECT bitmapOrCardinality(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:01.684406 [ 3355 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:01.744610 [ 3330 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:01.860693 [ 30720 ] {9bdd9506-d94c-4f2e-8318-6c324007a227} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapToArray doesn't match: passed 3, should be 1: In scope SELECT bitmapToArray(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitmapToArray(NULL, NULL, NULL);) 2025.10.23 23:49:01.864830 [ 30720 ] {9bdd9506-d94c-4f2e-8318-6c324007a227} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapToArray doesn't match: passed 3, should be 1: In scope SELECT bitmapToArray(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:02.025513 [ 30720 ] {bebd6368-7f75-4491-84d8-977d1a2d11b7} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapXor doesn't match: passed 3, should be 2: In scope SELECT bitmapXor(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitmapXor(NULL, NULL, NULL);) 2025.10.23 23:49:02.028991 [ 30720 ] {bebd6368-7f75-4491-84d8-977d1a2d11b7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapXor doesn't match: passed 3, should be 2: In scope SELECT bitmapXor(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:02.070151 [ 30720 ] {c1a311dd-ae3e-482b-8077-1bee9ef099c1} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapXorCardinality doesn't match: passed 3, should be 2: In scope SELECT bitmapXorCardinality(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitmapXorCardinality(NULL, NULL, NULL);) 2025.10.23 23:49:02.073588 [ 30720 ] {c1a311dd-ae3e-482b-8077-1bee9ef099c1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapXorCardinality doesn't match: passed 3, should be 2: In scope SELECT bitmapXorCardinality(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:02.190932 [ 30720 ] {a24de8ce-8804-402b-b198-d081226f5559} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmaskToArray doesn't match: passed 3, should be 1: In scope SELECT bitmaskToArray(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitmaskToArray(NULL, NULL, NULL);) 2025.10.23 23:49:02.194695 [ 30720 ] {a24de8ce-8804-402b-b198-d081226f5559} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmaskToArray doesn't match: passed 3, should be 1: In scope SELECT bitmaskToArray(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:02.239548 [ 30720 ] {0b28c951-7944-496d-8000-02fa963edd68} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmaskToList doesn't match: passed 3, should be 1: In scope SELECT bitmaskToList(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitmaskToList(NULL, NULL, NULL);) 2025.10.23 23:49:02.243323 [ 30720 ] {0b28c951-7944-496d-8000-02fa963edd68} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmaskToList doesn't match: passed 3, should be 1: In scope SELECT bitmaskToList(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:02.283153 [ 30720 ] {551bfe3f-fad7-43a7-8985-38bf12d1c27c} executeQuery: Code: 42. DB::Exception: Number of arguments for function blockNumber doesn't match: passed 3, should be 0: In scope SELECT blockNumber(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT blockNumber(NULL, NULL, NULL);) 2025.10.23 23:49:02.327352 [ 3332 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:02.327426 [ 3342 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:02.328386 [ 30720 ] {551bfe3f-fad7-43a7-8985-38bf12d1c27c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function blockNumber doesn't match: passed 3, should be 0: In scope SELECT blockNumber(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:02.330371 [ 3316 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:02.471077 [ 3314 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:02.566842 [ 30720 ] {cba1be0a-5f0e-46ca-a094-56487efe3878} executeQuery: Code: 42. DB::Exception: Number of arguments for function blockSize doesn't match: passed 3, should be 0: In scope SELECT blockSize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT blockSize(NULL, NULL, NULL);) 2025.10.23 23:49:02.569456 [ 30720 ] {cba1be0a-5f0e-46ca-a094-56487efe3878} TCPHandler: Code: 42. DB::Exception: Number of arguments for function blockSize doesn't match: passed 3, should be 0: In scope SELECT blockSize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:02.685301 [ 3307 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:02.745528 [ 3321 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:02.771531 [ 30720 ] {4b9feacd-e72d-4ca7-8e59-111f0f9027a5} executeQuery: Code: 42. DB::Exception: Number of arguments for function buildId doesn't match: passed 3, should be 0: In scope SELECT buildId(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT buildId(NULL, NULL, NULL);) 2025.10.23 23:49:02.774251 [ 30720 ] {4b9feacd-e72d-4ca7-8e59-111f0f9027a5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function buildId doesn't match: passed 3, should be 0: In scope SELECT buildId(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:02.805644 [ 30720 ] {ceeae17c-9196-41fb-9298-7d3c72aa293f} executeQuery: Code: 42. DB::Exception: Number of arguments for function byteHammingDistance doesn't match: passed 3, should be 2: In scope SELECT byteHammingDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT byteHammingDistance(NULL, NULL, NULL);) 2025.10.23 23:49:02.808537 [ 30720 ] {ceeae17c-9196-41fb-9298-7d3c72aa293f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function byteHammingDistance doesn't match: passed 3, should be 2: In scope SELECT byteHammingDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:03.139716 [ 30720 ] {251aa0f1-e194-4ceb-8105-e13578c41736} executeQuery: Code: 42. DB::Exception: Number of arguments for function byteSwap doesn't match: passed 3, should be 1: In scope SELECT byteSwap(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT byteSwap(NULL, NULL, NULL);) 2025.10.23 23:49:03.143903 [ 30720 ] {251aa0f1-e194-4ceb-8105-e13578c41736} TCPHandler: Code: 42. DB::Exception: Number of arguments for function byteSwap doesn't match: passed 3, should be 1: In scope SELECT byteSwap(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:03.334274 [ 3302 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:03.334427 [ 3295 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:03.334563 [ 3290 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:03.472674 [ 3286 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:03.680571 [ 30720 ] {d2a42e58-fe03-4b12-8d1c-85925150f27a} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function catboostEvaluate, expected a string.: In scope SELECT catboostEvaluate(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT catboostEvaluate(NULL, NULL, NULL);) 2025.10.23 23:49:03.683999 [ 30720 ] {d2a42e58-fe03-4b12-8d1c-85925150f27a} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function catboostEvaluate, expected a string.: In scope SELECT catboostEvaluate(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:49:03.686371 [ 3283 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:03.726101 [ 30720 ] {050eae91-bdef-4d43-8e9d-de478c649a1d} executeQuery: Code: 43. DB::Exception: All the arguments of aggregate function categoricalInformationValue should be UInt8. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT categoricalInformationValue(NULL, NULL, NULL);) 2025.10.23 23:49:03.730021 [ 30720 ] {050eae91-bdef-4d43-8e9d-de478c649a1d} TCPHandler: Code: 43. DB::Exception: All the arguments of aggregate function categoricalInformationValue should be UInt8. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:49:03.746573 [ 3279 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:03.773734 [ 30720 ] {dee9d4fd-c94d-4b98-8efc-38982fb8f9a0} executeQuery: Code: 42. DB::Exception: Number of arguments for function cbrt doesn't match: passed 3, should be 1: In scope SELECT cbrt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT cbrt(NULL, NULL, NULL);) 2025.10.23 23:49:03.777881 [ 30720 ] {dee9d4fd-c94d-4b98-8efc-38982fb8f9a0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cbrt doesn't match: passed 3, should be 1: In scope SELECT cbrt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:03.985949 [ 30720 ] {3d669992-8d3c-417b-8aea-1b7abc8660c7} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeDay doesn't match: passed 3, should be 2: In scope SELECT changeDay(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT changeDay(NULL, NULL, NULL);) 2025.10.23 23:49:03.989899 [ 30720 ] {3d669992-8d3c-417b-8aea-1b7abc8660c7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeDay doesn't match: passed 3, should be 2: In scope SELECT changeDay(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:04.033950 [ 30720 ] {e630788f-941d-4030-9e5b-dc2aa81efc0a} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeHour doesn't match: passed 3, should be 2: In scope SELECT changeHour(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT changeHour(NULL, NULL, NULL);) 2025.10.23 23:49:04.037806 [ 30720 ] {e630788f-941d-4030-9e5b-dc2aa81efc0a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeHour doesn't match: passed 3, should be 2: In scope SELECT changeHour(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:04.081493 [ 30720 ] {8f9c593a-cbba-4fd7-818a-cf100f02364d} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeMinute doesn't match: passed 3, should be 2: In scope SELECT changeMinute(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT changeMinute(NULL, NULL, NULL);) 2025.10.23 23:49:04.085201 [ 30720 ] {8f9c593a-cbba-4fd7-818a-cf100f02364d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeMinute doesn't match: passed 3, should be 2: In scope SELECT changeMinute(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:04.173875 [ 30720 ] {73cbb124-4824-4133-b77e-d1c3032310d6} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeMonth doesn't match: passed 3, should be 2: In scope SELECT changeMonth(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT changeMonth(NULL, NULL, NULL);) 2025.10.23 23:49:04.177615 [ 30720 ] {73cbb124-4824-4133-b77e-d1c3032310d6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeMonth doesn't match: passed 3, should be 2: In scope SELECT changeMonth(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:04.222685 [ 30720 ] {3d51c4fd-bc18-4dfa-876e-e1d7ad3955ee} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeSecond doesn't match: passed 3, should be 2: In scope SELECT changeSecond(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT changeSecond(NULL, NULL, NULL);) 2025.10.23 23:49:04.226559 [ 30720 ] {3d51c4fd-bc18-4dfa-876e-e1d7ad3955ee} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeSecond doesn't match: passed 3, should be 2: In scope SELECT changeSecond(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:04.335268 [ 3257 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:04.335501 [ 3261 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:04.335958 [ 3274 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:04.338007 [ 30720 ] {b3be425d-2b5d-4199-ad9c-e0632809f3f8} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeYear doesn't match: passed 3, should be 2: In scope SELECT changeYear(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT changeYear(NULL, NULL, NULL);) 2025.10.23 23:49:04.342053 [ 30720 ] {b3be425d-2b5d-4199-ad9c-e0632809f3f8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeYear doesn't match: passed 3, should be 2: In scope SELECT changeYear(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:04.474171 [ 3255 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:04.687445 [ 3271 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:04.747947 [ 3251 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:05.336736 [ 3258 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:05.336864 [ 3239 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:05.337292 [ 3247 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:05.475270 [ 3224 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:05.600936 [ 30720 ] {576bd308-59bf-45cb-b666-108fa244e38c} executeQuery: Code: 42. DB::Exception: Number of arguments for function connectionId doesn't match: passed 3, should be 0: In scope SELECT connectionId(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT connectionId(NULL, NULL, NULL);) 2025.10.23 23:49:05.604892 [ 30720 ] {576bd308-59bf-45cb-b666-108fa244e38c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function connectionId doesn't match: passed 3, should be 0: In scope SELECT connectionId(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:05.667102 [ 30720 ] {39d60ed1-94f0-427e-a000-f377f3ec4387} executeQuery: Code: 42. DB::Exception: Number of arguments for function connectionId doesn't match: passed 3, should be 0: In scope SELECT connection_id(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT connection_id(NULL, NULL, NULL);) 2025.10.23 23:49:05.671270 [ 30720 ] {39d60ed1-94f0-427e-a000-f377f3ec4387} TCPHandler: Code: 42. DB::Exception: Number of arguments for function connectionId doesn't match: passed 3, should be 0: In scope SELECT connection_id(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:05.688308 [ 3216 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:05.749322 [ 3215 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:06.162772 [ 30720 ] {dd0af6ab-2ee1-443e-974c-0ce4c80a5703} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT corrMatrix(NULL, NULL, NULL);) 2025.10.23 23:49:06.168437 [ 30720 ] {dd0af6ab-2ee1-443e-974c-0ce4c80a5703} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) 2025.10.23 23:49:06.355493 [ 3198 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:06.355502 [ 3193 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:06.356222 [ 3194 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:06.476627 [ 3195 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:06.518648 [ 30720 ] {79f89738-5a12-45ef-9911-dcdea12cf72e} executeQuery: Code: 42. DB::Exception: Number of arguments for function cos doesn't match: passed 3, should be 1: In scope SELECT cos(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT cos(NULL, NULL, NULL);) 2025.10.23 23:49:06.521177 [ 30720 ] {79f89738-5a12-45ef-9911-dcdea12cf72e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cos doesn't match: passed 3, should be 1: In scope SELECT cos(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:06.549149 [ 30720 ] {a1978285-9fec-4836-8f37-075f0baeb6cd} executeQuery: Code: 42. DB::Exception: Number of arguments for function cosh doesn't match: passed 3, should be 1: In scope SELECT cosh(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT cosh(NULL, NULL, NULL);) 2025.10.23 23:49:06.551437 [ 30720 ] {a1978285-9fec-4836-8f37-075f0baeb6cd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cosh doesn't match: passed 3, should be 1: In scope SELECT cosh(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:06.590289 [ 30720 ] {853ef49a-1167-4bd5-ab1e-355397316b20} executeQuery: Code: 42. DB::Exception: Number of arguments for function cosineDistance doesn't match: passed 3, should be 2: In scope SELECT cosineDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT cosineDistance(NULL, NULL, NULL);) 2025.10.23 23:49:06.617886 [ 30720 ] {853ef49a-1167-4bd5-ab1e-355397316b20} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cosineDistance doesn't match: passed 3, should be 2: In scope SELECT cosineDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:06.645580 [ 30720 ] {85c6fd99-930d-4eb3-bc1a-549e5ff51882} executeQuery: Code: 42. DB::Exception: Aggregate function count requires zero or one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT count(NULL, NULL, NULL);) 2025.10.23 23:49:06.648212 [ 30720 ] {85c6fd99-930d-4eb3-bc1a-549e5ff51882} TCPHandler: Code: 42. DB::Exception: Aggregate function count requires zero or one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:06.689089 [ 3186 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:06.750236 [ 3181 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:06.766383 [ 30720 ] {6d941a2d-f724-446d-a9ab-9d0851b1d113} executeQuery: Code: 42. DB::Exception: Number of arguments for function countDigits doesn't match: passed 3, should be 1: In scope SELECT countDigits(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT countDigits(NULL, NULL, NULL);) 2025.10.23 23:49:06.769172 [ 30720 ] {6d941a2d-f724-446d-a9ab-9d0851b1d113} TCPHandler: Code: 42. DB::Exception: Number of arguments for function countDigits doesn't match: passed 3, should be 1: In scope SELECT countDigits(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:06.857002 [ 30720 ] {2f75a07c-999c-46ff-845f-597b0b67b63e} executeQuery: Code: 42. DB::Exception: Number of arguments for function countEqual doesn't match: passed 3, should be 2: In scope SELECT countEqual(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT countEqual(NULL, NULL, NULL);) 2025.10.23 23:49:06.859543 [ 30720 ] {2f75a07c-999c-46ff-845f-597b0b67b63e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function countEqual doesn't match: passed 3, should be 2: In scope SELECT countEqual(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:06.887209 [ 30720 ] {3cd804a9-456e-43e9-a5e1-c7e5b8cfbc05} executeQuery: Code: 42. DB::Exception: Number of arguments for function countMatches doesn't match: passed 3, should be 2: In scope SELECT countMatches(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT countMatches(NULL, NULL, NULL);) 2025.10.23 23:49:06.950358 [ 30720 ] {3cd804a9-456e-43e9-a5e1-c7e5b8cfbc05} TCPHandler: Code: 42. DB::Exception: Number of arguments for function countMatches doesn't match: passed 3, should be 2: In scope SELECT countMatches(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:06.984658 [ 30720 ] {dcbc211e-c91f-45e0-8040-d405b15d0bc9} executeQuery: Code: 42. DB::Exception: Number of arguments for function countMatchesCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT countMatchesCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT countMatchesCaseInsensitive(NULL, NULL, NULL);) 2025.10.23 23:49:06.988579 [ 30720 ] {dcbc211e-c91f-45e0-8040-d405b15d0bc9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function countMatchesCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT countMatchesCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:07.356582 [ 3148 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:07.357042 [ 3158 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:07.357332 [ 3161 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:07.477754 [ 3139 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:07.689939 [ 3138 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:07.751483 [ 3144 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:08.357536 [ 3121 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:08.357885 [ 3116 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:08.358297 [ 3119 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:08.393820 [ 30720 ] {69406e91-9553-46ef-8b1c-239899f73330} executeQuery: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 3, should be 0: In scope SELECT curdate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT curdate(NULL, NULL, NULL);) 2025.10.23 23:49:08.396278 [ 30720 ] {69406e91-9553-46ef-8b1c-239899f73330} TCPHandler: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 3, should be 0: In scope SELECT curdate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:08.422270 [ 30720 ] {95aea884-b46c-45e1-9e7f-7458b39672f4} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 3, should be 0: In scope SELECT currentDatabase(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT currentDatabase(NULL, NULL, NULL);) 2025.10.23 23:49:08.425078 [ 30720 ] {95aea884-b46c-45e1-9e7f-7458b39672f4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 3, should be 0: In scope SELECT currentDatabase(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:08.451137 [ 30720 ] {dd84e816-e2f0-43b8-a49d-d0110b8485fb} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentProfiles doesn't match: passed 3, should be 0: In scope SELECT currentProfiles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT currentProfiles(NULL, NULL, NULL);) 2025.10.23 23:49:08.453526 [ 30720 ] {dd84e816-e2f0-43b8-a49d-d0110b8485fb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentProfiles doesn't match: passed 3, should be 0: In scope SELECT currentProfiles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:08.478739 [ 3162 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:08.479403 [ 30720 ] {034ac17a-2a5c-451c-901d-098ffbdf9cdc} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentRoles doesn't match: passed 3, should be 0: In scope SELECT currentRoles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT currentRoles(NULL, NULL, NULL);) 2025.10.23 23:49:08.481679 [ 30720 ] {034ac17a-2a5c-451c-901d-098ffbdf9cdc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentRoles doesn't match: passed 3, should be 0: In scope SELECT currentRoles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:08.507201 [ 30720 ] {ce3889de-7d6b-4988-a76e-48a1387732d3} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentSchemas doesn't match: passed 3, should be 1: In scope SELECT currentSchemas(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT currentSchemas(NULL, NULL, NULL);) 2025.10.23 23:49:08.509643 [ 30720 ] {ce3889de-7d6b-4988-a76e-48a1387732d3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentSchemas doesn't match: passed 3, should be 1: In scope SELECT currentSchemas(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:08.536559 [ 30720 ] {d74896e9-d4af-4df7-8b1b-7433a87db7ce} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 3, should be 0: In scope SELECT currentUser(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT currentUser(NULL, NULL, NULL);) 2025.10.23 23:49:08.538893 [ 30720 ] {d74896e9-d4af-4df7-8b1b-7433a87db7ce} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 3, should be 0: In scope SELECT currentUser(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:08.586972 [ 30720 ] {2e75f911-097a-4f7a-9c15-70934e3daa9a} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 3, should be 0: In scope SELECT current_database(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT current_database(NULL, NULL, NULL);) 2025.10.23 23:49:08.589523 [ 30720 ] {2e75f911-097a-4f7a-9c15-70934e3daa9a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 3, should be 0: In scope SELECT current_database(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:08.615712 [ 30720 ] {dfcddb25-cfe9-4e65-8c0b-cbfb6d4df1c2} executeQuery: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 3, should be 0: In scope SELECT current_date(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT current_date(NULL, NULL, NULL);) 2025.10.23 23:49:08.618383 [ 30720 ] {dfcddb25-cfe9-4e65-8c0b-cbfb6d4df1c2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 3, should be 0: In scope SELECT current_date(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:08.644813 [ 30720 ] {1e7a759a-faf8-4f1c-861e-45e0abeb5e05} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentSchemas doesn't match: passed 3, should be 1: In scope SELECT current_schemas(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT current_schemas(NULL, NULL, NULL);) 2025.10.23 23:49:08.647280 [ 30720 ] {1e7a759a-faf8-4f1c-861e-45e0abeb5e05} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentSchemas doesn't match: passed 3, should be 1: In scope SELECT current_schemas(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:08.674938 [ 30720 ] {6b317862-1e86-46a3-8b82-3b6062f1bebd} executeQuery: Code: 42. DB::Exception: Arguments size of function now should be 0 or 1: In scope SELECT current_timestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT current_timestamp(NULL, NULL, NULL);) 2025.10.23 23:49:08.678183 [ 30720 ] {6b317862-1e86-46a3-8b82-3b6062f1bebd} TCPHandler: Code: 42. DB::Exception: Arguments size of function now should be 0 or 1: In scope SELECT current_timestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:08.690974 [ 3108 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:08.706413 [ 30720 ] {9523fc45-56c5-4907-864f-76b33eee4d6f} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 3, should be 0: In scope SELECT current_user(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT current_user(NULL, NULL, NULL);) 2025.10.23 23:49:08.709533 [ 30720 ] {9523fc45-56c5-4907-864f-76b33eee4d6f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 3, should be 0: In scope SELECT current_user(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:08.738270 [ 30720 ] {b61ff92f-a524-4710-b02f-2968ed2173a8} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutFragment doesn't match: passed 3, should be 1: In scope SELECT cutFragment(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT cutFragment(NULL, NULL, NULL);) 2025.10.23 23:49:08.741304 [ 30720 ] {b61ff92f-a524-4710-b02f-2968ed2173a8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutFragment doesn't match: passed 3, should be 1: In scope SELECT cutFragment(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:08.774647 [ 3109 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:08.907106 [ 30720 ] {361345d7-f40b-4911-9b7c-bbe9934cfbab} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutQueryString doesn't match: passed 3, should be 1: In scope SELECT cutQueryString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT cutQueryString(NULL, NULL, NULL);) 2025.10.23 23:49:08.910694 [ 30720 ] {361345d7-f40b-4911-9b7c-bbe9934cfbab} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutQueryString doesn't match: passed 3, should be 1: In scope SELECT cutQueryString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:08.987651 [ 30720 ] {e5a363eb-71b7-4ffc-93d3-454bab7b722f} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutQueryStringAndFragment doesn't match: passed 3, should be 1: In scope SELECT cutQueryStringAndFragment(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT cutQueryStringAndFragment(NULL, NULL, NULL);) 2025.10.23 23:49:09.058566 [ 30720 ] {e5a363eb-71b7-4ffc-93d3-454bab7b722f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutQueryStringAndFragment doesn't match: passed 3, should be 1: In scope SELECT cutQueryStringAndFragment(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:09.087335 [ 30720 ] {e51fd2d1-6949-461a-99e3-f537ede71991} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomain doesn't match: passed 3, should be 1: In scope SELECT cutToFirstSignificantSubdomain(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT cutToFirstSignificantSubdomain(NULL, NULL, NULL);) 2025.10.23 23:49:09.090183 [ 30720 ] {e51fd2d1-6949-461a-99e3-f537ede71991} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomain doesn't match: passed 3, should be 1: In scope SELECT cutToFirstSignificantSubdomain(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:09.115832 [ 30720 ] {0bbeacc6-19e3-43ca-8b83-8500765f7631} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustom doesn't match: passed 3, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustom(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT cutToFirstSignificantSubdomainCustom(NULL, NULL, NULL);) 2025.10.23 23:49:09.118363 [ 30720 ] {0bbeacc6-19e3-43ca-8b83-8500765f7631} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustom doesn't match: passed 3, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustom(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:09.147313 [ 30720 ] {abc0a03b-b01e-4614-8742-64f27b2e4662} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomRFC doesn't match: passed 3, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT cutToFirstSignificantSubdomainCustomRFC(NULL, NULL, NULL);) 2025.10.23 23:49:09.150011 [ 30720 ] {abc0a03b-b01e-4614-8742-64f27b2e4662} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomRFC doesn't match: passed 3, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:09.176648 [ 30720 ] {129cf619-af6c-4e4b-b914-787ebccdc984} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomWithWWW doesn't match: passed 3, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomWithWWW(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT cutToFirstSignificantSubdomainCustomWithWWW(NULL, NULL, NULL);) 2025.10.23 23:49:09.179077 [ 30720 ] {129cf619-af6c-4e4b-b914-787ebccdc984} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomWithWWW doesn't match: passed 3, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomWithWWW(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:09.204799 [ 30720 ] {4b15f178-6d2a-4d22-8d87-1910d843ec08} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomWithWWWRFC doesn't match: passed 3, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomWithWWWRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT cutToFirstSignificantSubdomainCustomWithWWWRFC(NULL, NULL, NULL);) 2025.10.23 23:49:09.207104 [ 30720 ] {4b15f178-6d2a-4d22-8d87-1910d843ec08} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomWithWWWRFC doesn't match: passed 3, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomWithWWWRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:09.234260 [ 30720 ] {d877e4b9-ffd4-4a0f-98bf-4a32c1deaa40} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainRFC doesn't match: passed 3, should be 1: In scope SELECT cutToFirstSignificantSubdomainRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT cutToFirstSignificantSubdomainRFC(NULL, NULL, NULL);) 2025.10.23 23:49:09.236973 [ 30720 ] {d877e4b9-ffd4-4a0f-98bf-4a32c1deaa40} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainRFC doesn't match: passed 3, should be 1: In scope SELECT cutToFirstSignificantSubdomainRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:09.264181 [ 30720 ] {19cbfa4c-03ca-4847-ad64-243bf2e6872d} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainWithWWW doesn't match: passed 3, should be 1: In scope SELECT cutToFirstSignificantSubdomainWithWWW(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT cutToFirstSignificantSubdomainWithWWW(NULL, NULL, NULL);) 2025.10.23 23:49:09.266839 [ 30720 ] {19cbfa4c-03ca-4847-ad64-243bf2e6872d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainWithWWW doesn't match: passed 3, should be 1: In scope SELECT cutToFirstSignificantSubdomainWithWWW(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:09.294825 [ 30720 ] {610a53f0-043c-43de-be47-05f0a5fb2198} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainWithWWWRFC doesn't match: passed 3, should be 1: In scope SELECT cutToFirstSignificantSubdomainWithWWWRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT cutToFirstSignificantSubdomainWithWWWRFC(NULL, NULL, NULL);) 2025.10.23 23:49:09.299340 [ 30720 ] {610a53f0-043c-43de-be47-05f0a5fb2198} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainWithWWWRFC doesn't match: passed 3, should be 1: In scope SELECT cutToFirstSignificantSubdomainWithWWWRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:09.326725 [ 30720 ] {6183b8ed-4ae3-4397-ae81-ec1ce9e89ee1} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutURLParameter doesn't match: passed 3, should be 2: In scope SELECT cutURLParameter(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT cutURLParameter(NULL, NULL, NULL);) 2025.10.23 23:49:09.358394 [ 3087 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:09.358403 [ 3088 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:09.359398 [ 3083 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:09.378144 [ 30720 ] {6183b8ed-4ae3-4397-ae81-ec1ce9e89ee1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutURLParameter doesn't match: passed 3, should be 2: In scope SELECT cutURLParameter(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:09.444143 [ 30720 ] {931baaca-f089-42da-81af-35636845d01a} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutWWW doesn't match: passed 3, should be 1: In scope SELECT cutWWW(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT cutWWW(NULL, NULL, NULL);) 2025.10.23 23:49:09.447949 [ 30720 ] {931baaca-f089-42da-81af-35636845d01a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutWWW doesn't match: passed 3, should be 1: In scope SELECT cutWWW(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:09.480212 [ 3071 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:09.487620 [ 30720 ] {53e37525-8ee7-42b2-a7f2-1cd3cc17088a} executeQuery: Code: 42. DB::Exception: Number of arguments for function damerauLevenshteinDistance doesn't match: passed 3, should be 2: In scope SELECT damerauLevenshteinDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT damerauLevenshteinDistance(NULL, NULL, NULL);) 2025.10.23 23:49:09.491602 [ 30720 ] {53e37525-8ee7-42b2-a7f2-1cd3cc17088a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function damerauLevenshteinDistance doesn't match: passed 3, should be 2: In scope SELECT damerauLevenshteinDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:09.646732 [ 30720 ] {f014cb2b-2f2f-4018-8a76-40a2744aeb7a} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=752). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT dateName(NULL, NULL, NULL);) 2025.10.23 23:49:09.666734 [ 30720 ] {f014cb2b-2f2f-4018-8a76-40a2744aeb7a} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=752). (CANNOT_SCHEDULE_TASK) 2025.10.23 23:49:09.692119 [ 3084 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:09.693273 [ 30720 ] {6be0b3ef-dfdd-4c73-945c-3a899267045e} executeQuery: Code: 42. DB::Exception: Number of arguments for function dateTime64ToSnowflake doesn't match: passed 3, should be 1: In scope SELECT dateTime64ToSnowflake(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT dateTime64ToSnowflake(NULL, NULL, NULL);) 2025.10.23 23:49:09.695651 [ 30720 ] {6be0b3ef-dfdd-4c73-945c-3a899267045e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dateTime64ToSnowflake doesn't match: passed 3, should be 1: In scope SELECT dateTime64ToSnowflake(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:09.764139 [ 30720 ] {fc416469-da37-4ce1-be12-c314d20ae439} executeQuery: Code: 42. DB::Exception: Number of arguments for function dateTimeToSnowflake doesn't match: passed 3, should be 1: In scope SELECT dateTimeToSnowflake(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT dateTimeToSnowflake(NULL, NULL, NULL);) 2025.10.23 23:49:09.767224 [ 30720 ] {fc416469-da37-4ce1-be12-c314d20ae439} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dateTimeToSnowflake doesn't match: passed 3, should be 1: In scope SELECT dateTimeToSnowflake(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:09.775851 [ 3095 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:10.064106 [ 30720 ] {ea9b8950-58bd-421c-b9e5-a82bffd577c1} executeQuery: Code: 42. DB::Exception: Number of arguments for function decodeHTMLComponent doesn't match: passed 3, should be 1: In scope SELECT decodeHTMLComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT decodeHTMLComponent(NULL, NULL, NULL);) 2025.10.23 23:49:10.066662 [ 30720 ] {ea9b8950-58bd-421c-b9e5-a82bffd577c1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function decodeHTMLComponent doesn't match: passed 3, should be 1: In scope SELECT decodeHTMLComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:10.126760 [ 30720 ] {909582ed-bb6e-4c94-9a29-b3ca496fde80} executeQuery: Code: 42. DB::Exception: Number of arguments for function decodeURLComponent doesn't match: passed 3, should be 1: In scope SELECT decodeURLComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT decodeURLComponent(NULL, NULL, NULL);) 2025.10.23 23:49:10.129232 [ 30720 ] {909582ed-bb6e-4c94-9a29-b3ca496fde80} TCPHandler: Code: 42. DB::Exception: Number of arguments for function decodeURLComponent doesn't match: passed 3, should be 1: In scope SELECT decodeURLComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:10.155459 [ 30720 ] {31aeef75-88dc-403e-9a4e-b0bed68c554c} executeQuery: Code: 42. DB::Exception: Number of arguments for function decodeURLFormComponent doesn't match: passed 3, should be 1: In scope SELECT decodeURLFormComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT decodeURLFormComponent(NULL, NULL, NULL);) 2025.10.23 23:49:10.158023 [ 30720 ] {31aeef75-88dc-403e-9a4e-b0bed68c554c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function decodeURLFormComponent doesn't match: passed 3, should be 1: In scope SELECT decodeURLFormComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:10.184259 [ 30720 ] {d5d4361e-31ff-4c15-a3e2-60fd1cb0ed98} executeQuery: Code: 42. DB::Exception: Number of arguments for function decodeXMLComponent doesn't match: passed 3, should be 1: In scope SELECT decodeXMLComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT decodeXMLComponent(NULL, NULL, NULL);) 2025.10.23 23:49:10.186775 [ 30720 ] {d5d4361e-31ff-4c15-a3e2-60fd1cb0ed98} TCPHandler: Code: 42. DB::Exception: Number of arguments for function decodeXMLComponent doesn't match: passed 3, should be 1: In scope SELECT decodeXMLComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:10.359395 [ 3059 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:10.359468 [ 3062 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:10.361146 [ 3104 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:10.361658 [ 30720 ] {c04b7f93-84be-4d2a-bee6-1852af7c95df} executeQuery: Code: 42. DB::Exception: Number of arguments for function defaultProfiles doesn't match: passed 3, should be 0: In scope SELECT defaultProfiles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT defaultProfiles(NULL, NULL, NULL);) 2025.10.23 23:49:10.365663 [ 30720 ] {c04b7f93-84be-4d2a-bee6-1852af7c95df} TCPHandler: Code: 42. DB::Exception: Number of arguments for function defaultProfiles doesn't match: passed 3, should be 0: In scope SELECT defaultProfiles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:10.410079 [ 30720 ] {d4c70dc2-fdcb-4131-88c5-b3593fdd6890} executeQuery: Code: 42. DB::Exception: Number of arguments for function defaultRoles doesn't match: passed 3, should be 0: In scope SELECT defaultRoles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT defaultRoles(NULL, NULL, NULL);) 2025.10.23 23:49:10.414096 [ 30720 ] {d4c70dc2-fdcb-4131-88c5-b3593fdd6890} TCPHandler: Code: 42. DB::Exception: Number of arguments for function defaultRoles doesn't match: passed 3, should be 0: In scope SELECT defaultRoles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:10.481366 [ 3055 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:10.652256 [ 30720 ] {014d387b-c8c9-4fa0-90f8-fbf11f2c4d6d} executeQuery: Code: 42. DB::Exception: Number of arguments for function defaultValueOfArgumentType doesn't match: passed 3, should be 1: In scope SELECT defaultValueOfArgumentType(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT defaultValueOfArgumentType(NULL, NULL, NULL);) 2025.10.23 23:49:10.654862 [ 30720 ] {014d387b-c8c9-4fa0-90f8-fbf11f2c4d6d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function defaultValueOfArgumentType doesn't match: passed 3, should be 1: In scope SELECT defaultValueOfArgumentType(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:10.681888 [ 30720 ] {bbba6952-f4c8-489c-acd7-b5ee82fc0516} executeQuery: Code: 42. DB::Exception: Number of arguments for function defaultValueOfTypeName doesn't match: passed 3, should be 1: In scope SELECT defaultValueOfTypeName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT defaultValueOfTypeName(NULL, NULL, NULL);) 2025.10.23 23:49:10.684632 [ 30720 ] {bbba6952-f4c8-489c-acd7-b5ee82fc0516} TCPHandler: Code: 42. DB::Exception: Number of arguments for function defaultValueOfTypeName doesn't match: passed 3, should be 1: In scope SELECT defaultValueOfTypeName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:10.692973 [ 3067 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:10.711062 [ 30720 ] {f1ddf510-9fe2-49bb-8bc6-595bf3f6e1cf} executeQuery: Code: 42. DB::Exception: Number of arguments for function degrees doesn't match: passed 3, should be 1: In scope SELECT degrees(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT degrees(NULL, NULL, NULL);) 2025.10.23 23:49:10.717249 [ 30720 ] {f1ddf510-9fe2-49bb-8bc6-595bf3f6e1cf} TCPHandler: Code: 42. DB::Exception: Number of arguments for function degrees doesn't match: passed 3, should be 1: In scope SELECT degrees(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:10.745483 [ 30720 ] {9ce58555-5381-4e63-a276-b67db093cdee} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function deltaSum. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT deltaSum(NULL, NULL, NULL);) 2025.10.23 23:49:10.748268 [ 30720 ] {9ce58555-5381-4e63-a276-b67db093cdee} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function deltaSum. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:10.776881 [ 3443 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:10.779494 [ 30720 ] {e73863b9-e1b6-42f5-ae29-5ff135c8d464} executeQuery: Code: 42. DB::Exception: Aggregate function deltaSumTimestamp requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT deltaSumTimestamp(NULL, NULL, NULL);) 2025.10.23 23:49:10.833383 [ 30720 ] {e73863b9-e1b6-42f5-ae29-5ff135c8d464} TCPHandler: Code: 42. DB::Exception: Aggregate function deltaSumTimestamp requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:10.892863 [ 30720 ] {7588a22a-0890-45fe-babb-9cb502d8de02} executeQuery: Code: 42. DB::Exception: Number of arguments for function demangle doesn't match: passed 3, should be 1: In scope SELECT demangle(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT demangle(NULL, NULL, NULL);) 2025.10.23 23:49:10.895270 [ 30720 ] {7588a22a-0890-45fe-babb-9cb502d8de02} TCPHandler: Code: 42. DB::Exception: Number of arguments for function demangle doesn't match: passed 3, should be 1: In scope SELECT demangle(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:10.954660 [ 30720 ] {2ce171f3-07e2-4c16-b74f-90c8778249a3} executeQuery: Code: 36. DB::Exception: The function 'denseRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT denseRank(NULL, NULL, NULL);) 2025.10.23 23:49:10.958546 [ 30720 ] {2ce171f3-07e2-4c16-b74f-90c8778249a3} TCPHandler: Code: 36. DB::Exception: The function 'denseRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.10.23 23:49:11.004962 [ 30720 ] {5d395a02-c948-4457-b6c7-28d8891d71c2} executeQuery: Code: 36. DB::Exception: The function 'denseRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT dense_rank(NULL, NULL, NULL);) 2025.10.23 23:49:11.013148 [ 30720 ] {5d395a02-c948-4457-b6c7-28d8891d71c2} TCPHandler: Code: 36. DB::Exception: The function 'denseRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.10.23 23:49:11.053512 [ 30720 ] {e766ef30-db8a-48ee-a680-95222bad0fa2} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectCharset' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT detectCharset(NULL, NULL, NULL);) 2025.10.23 23:49:11.057241 [ 30720 ] {e766ef30-db8a-48ee-a680-95222bad0fa2} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectCharset' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.10.23 23:49:11.101532 [ 30720 ] {12824428-0a3c-4c3c-95a0-78675fa52623} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectLanguage' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT detectLanguage(NULL, NULL, NULL);) 2025.10.23 23:49:11.105475 [ 30720 ] {12824428-0a3c-4c3c-95a0-78675fa52623} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectLanguage' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.10.23 23:49:11.148151 [ 30720 ] {923afc9b-7ef5-4a07-bc77-42c32d65d25f} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectLanguageMixed' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT detectLanguageMixed(NULL, NULL, NULL);) 2025.10.23 23:49:11.151569 [ 30720 ] {923afc9b-7ef5-4a07-bc77-42c32d65d25f} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectLanguageMixed' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.10.23 23:49:11.196619 [ 30720 ] {04c1a75e-9fcc-4747-ad81-f90975d97a61} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectLanguageUnknown' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT detectLanguageUnknown(NULL, NULL, NULL);) 2025.10.23 23:49:11.199895 [ 30720 ] {04c1a75e-9fcc-4747-ad81-f90975d97a61} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectLanguageUnknown' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.10.23 23:49:11.244303 [ 30720 ] {f923dc2e-f55a-41d2-8bdc-8de1cd137012} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectProgrammingLanguage' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT detectProgrammingLanguage(NULL, NULL, NULL);) 2025.10.23 23:49:11.248089 [ 30720 ] {f923dc2e-f55a-41d2-8bdc-8de1cd137012} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectProgrammingLanguage' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.10.23 23:49:11.290643 [ 30720 ] {5ed1380f-c57b-4df5-a4bb-b5de89d4c031} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectTonality' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT detectTonality(NULL, NULL, NULL);) 2025.10.23 23:49:11.294861 [ 30720 ] {5ed1380f-c57b-4df5-a4bb-b5de89d4c031} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectTonality' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.10.23 23:49:11.338299 [ 30720 ] {ad57bcc5-c012-4117-958d-1519cdf93d35} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function dictGet, expected a const string.: In scope SELECT dictGet(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT dictGet(NULL, NULL, NULL);) 2025.10.23 23:49:11.341881 [ 30720 ] {ad57bcc5-c012-4117-958d-1519cdf93d35} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function dictGet, expected a const string.: In scope SELECT dictGet(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:49:11.360409 [ 3236 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:11.360692 [ 3223 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:11.362302 [ 3265 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:11.399580 [ 3656 ] {} 0edaf248-9c79-42ba-a156-08c185e86370::0_0_0_0_1 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:11.400884 [ 3656 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {0edaf248-9c79-42ba-a156-08c185e86370::0_0_0_0_1}: 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:11.411680 [ 3646 ] {} 0edaf248-9c79-42ba-a156-08c185e86370::1_0_0_0_1 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=4, jobs=4). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:11.412649 [ 3646 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {0edaf248-9c79-42ba-a156-08c185e86370::1_0_0_0_1}: 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:11.482842 [ 3213 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:11.571039 [ 30720 ] {e05e4596-e556-4394-95e0-678f11b7e3b6} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function dictGetAll, expected a const string.: In scope SELECT dictGetAll(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT dictGetAll(NULL, NULL, NULL);) 2025.10.23 23:49:11.574703 [ 30720 ] {e05e4596-e556-4394-95e0-678f11b7e3b6} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function dictGetAll, expected a const string.: In scope SELECT dictGetAll(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:49:11.639283 [ 30720 ] {2edaf54f-622b-4eb5-9013-016c2415ffbf} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetChildren doesn't match: passed 3, should be 2: In scope SELECT dictGetChildren(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT dictGetChildren(NULL, NULL, NULL);) 2025.10.23 23:49:11.643259 [ 30720 ] {2edaf54f-622b-4eb5-9013-016c2415ffbf} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetChildren doesn't match: passed 3, should be 2: In scope SELECT dictGetChildren(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:11.693997 [ 3124 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:11.777897 [ 3135 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:12.122191 [ 30720 ] {18d6feea-b2e7-44fd-90ac-b506f38a83d0} executeQuery: Code: 1. DB::Exception: Expected const String column: In scope SELECT dictGetDescendants(NULL, NULL, NULL). (UNSUPPORTED_METHOD) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT dictGetDescendants(NULL, NULL, NULL);) 2025.10.23 23:49:12.126132 [ 30720 ] {18d6feea-b2e7-44fd-90ac-b506f38a83d0} TCPHandler: Code: 1. DB::Exception: Expected const String column: In scope SELECT dictGetDescendants(NULL, NULL, NULL). (UNSUPPORTED_METHOD) 2025.10.23 23:49:12.361674 [ 3540 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:12.361794 [ 3559 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:12.363627 [ 3550 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:12.564264 [ 3553 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:12.695027 [ 3527 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:12.779145 [ 3074 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:12.793012 [ 30720 ] {3d363b43-0fd4-4b87-8a63-9be58612c7c7} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetHierarchy doesn't match: passed 3, should be 2: In scope SELECT dictGetHierarchy(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT dictGetHierarchy(NULL, NULL, NULL);) 2025.10.23 23:49:12.797213 [ 30720 ] {3d363b43-0fd4-4b87-8a63-9be58612c7c7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetHierarchy doesn't match: passed 3, should be 2: In scope SELECT dictGetHierarchy(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:13.332682 [ 30720 ] {af305621-5faf-4364-8a60-fd3220d46fab} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=752). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT dictGetIPv6OrDefault(NULL, NULL, NULL);) 2025.10.23 23:49:13.335390 [ 30720 ] {af305621-5faf-4364-8a60-fd3220d46fab} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=752). (CANNOT_SCHEDULE_TASK) 2025.10.23 23:49:13.362715 [ 3549 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:13.362817 [ 3546 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:13.364776 [ 3519 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:13.565523 [ 3521 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:13.696341 [ 3511 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:13.780344 [ 3524 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:13.890546 [ 3642 ] {} CgroupsMemoryUsageObserver: Exceeded soft memory limit (13.77 GiB) 2025.10.23 23:49:14.240294 [ 30720 ] {debed5a0-79a7-4d1b-9bb6-1720aea2ee3f} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetOrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT dictGetOrDefault(NULL, NULL, NULL);) 2025.10.23 23:49:14.244135 [ 30720 ] {debed5a0-79a7-4d1b-9bb6-1720aea2ee3f} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetOrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:49:14.306743 [ 30720 ] {c23bd816-07ef-4cd8-a58f-bad377a9f306} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetOrNull(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT dictGetOrNull(NULL, NULL, NULL);) 2025.10.23 23:49:14.310727 [ 30720 ] {c23bd816-07ef-4cd8-a58f-bad377a9f306} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetOrNull(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:49:14.363630 [ 3501 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:14.363656 [ 3513 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:14.365847 [ 3499 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:14.372295 [ 4841 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x00000000315a10ad 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159da2f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b6b4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa269fb 10. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:14.566737 [ 3496 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:14.697251 [ 3493 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:14.781358 [ 3488 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:14.847490 [ 4841 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x00000000315a10ad 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159da2f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b6b4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa269fb 10. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:15.364807 [ 3475 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:15.364841 [ 3489 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:15.366850 [ 3490 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:15.568387 [ 3472 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:15.612143 [ 30720 ] {21435222-c327-4a84-98a3-5c2172634e97} executeQuery: Code: 42. DB::Exception: Number of arguments for function displayName doesn't match: passed 3, should be 0: In scope SELECT displayName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT displayName(NULL, NULL, NULL);) 2025.10.23 23:49:15.614784 [ 30720 ] {21435222-c327-4a84-98a3-5c2172634e97} TCPHandler: Code: 42. DB::Exception: Number of arguments for function displayName doesn't match: passed 3, should be 0: In scope SELECT displayName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:15.641044 [ 30720 ] {562ae9c7-8a52-4df5-8aa9-fef4e0518ac7} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Distance doesn't match: passed 3, should be 2: In scope SELECT distanceL1(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT distanceL1(NULL, NULL, NULL);) 2025.10.23 23:49:15.643429 [ 30720 ] {562ae9c7-8a52-4df5-8aa9-fef4e0518ac7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Distance doesn't match: passed 3, should be 2: In scope SELECT distanceL1(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:15.669863 [ 30720 ] {117573ca-4a19-41e0-a8de-238230735d8b} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Distance doesn't match: passed 3, should be 2: In scope SELECT distanceL2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT distanceL2(NULL, NULL, NULL);) 2025.10.23 23:49:15.672559 [ 30720 ] {117573ca-4a19-41e0-a8de-238230735d8b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Distance doesn't match: passed 3, should be 2: In scope SELECT distanceL2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:15.698082 [ 3466 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:15.742106 [ 30720 ] {29c40b63-54d5-43cc-93cf-e048d73406fe} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2SquaredDistance doesn't match: passed 3, should be 2: In scope SELECT distanceL2Squared(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT distanceL2Squared(NULL, NULL, NULL);) 2025.10.23 23:49:15.744652 [ 30720 ] {29c40b63-54d5-43cc-93cf-e048d73406fe} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2SquaredDistance doesn't match: passed 3, should be 2: In scope SELECT distanceL2Squared(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:15.780215 [ 30720 ] {9560a2e9-71bf-43f4-973c-0a31663efe80} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfDistance doesn't match: passed 3, should be 2: In scope SELECT distanceLinf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT distanceLinf(NULL, NULL, NULL);) 2025.10.23 23:49:15.782975 [ 30720 ] {9560a2e9-71bf-43f4-973c-0a31663efe80} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfDistance doesn't match: passed 3, should be 2: In scope SELECT distanceLinf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:15.835093 [ 3468 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:15.926167 [ 30720 ] {45a6a16c-7ecc-4c86-9ba6-f5ac19f1d5d0} executeQuery: Code: 42. DB::Exception: Number of arguments for function divide doesn't match: passed 3, should be 2: In scope SELECT divide(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT divide(NULL, NULL, NULL);) 2025.10.23 23:49:15.928790 [ 30720 ] {45a6a16c-7ecc-4c86-9ba6-f5ac19f1d5d0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function divide doesn't match: passed 3, should be 2: In scope SELECT divide(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:16.047530 [ 4841 ] {f29e27f8-303b-42f3-9dfa-7067a81cc7c6} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:33414) (comment: 01045_zookeeper_system_mutations_with_parts_names.sh) (in query: DROP DATABASE IF EXISTS test_g3s9dkw3 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:49:16.050305 [ 4841 ] {f29e27f8-303b-42f3-9dfa-7067a81cc7c6} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:16.176980 [ 30720 ] {1c6f5b90-4f29-485a-9aea-ebe03e546e22} executeQuery: Code: 42. DB::Exception: Number of arguments for function domain doesn't match: passed 3, should be 1: In scope SELECT domain(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT domain(NULL, NULL, NULL);) 2025.10.23 23:49:16.179914 [ 30720 ] {1c6f5b90-4f29-485a-9aea-ebe03e546e22} TCPHandler: Code: 42. DB::Exception: Number of arguments for function domain doesn't match: passed 3, should be 1: In scope SELECT domain(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:16.215013 [ 30720 ] {f70078f2-a264-46d5-a9a8-23412eff7ae1} executeQuery: Code: 42. DB::Exception: Number of arguments for function domainRFC doesn't match: passed 3, should be 1: In scope SELECT domainRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT domainRFC(NULL, NULL, NULL);) 2025.10.23 23:49:16.268844 [ 30720 ] {f70078f2-a264-46d5-a9a8-23412eff7ae1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function domainRFC doesn't match: passed 3, should be 1: In scope SELECT domainRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:16.305108 [ 30720 ] {70837d93-568e-4ce6-bc5f-01abb0b9bef2} executeQuery: Code: 42. DB::Exception: Number of arguments for function domainWithoutWWW doesn't match: passed 3, should be 1: In scope SELECT domainWithoutWWW(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT domainWithoutWWW(NULL, NULL, NULL);) 2025.10.23 23:49:16.307604 [ 30720 ] {70837d93-568e-4ce6-bc5f-01abb0b9bef2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function domainWithoutWWW doesn't match: passed 3, should be 1: In scope SELECT domainWithoutWWW(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:16.365807 [ 3452 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:16.365958 [ 3459 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:16.367931 [ 3453 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:16.406008 [ 30720 ] {362211f2-857c-4176-9f29-87f47511deed} executeQuery: Code: 42. DB::Exception: Number of arguments for function domainWithoutWWWRFC doesn't match: passed 3, should be 1: In scope SELECT domainWithoutWWWRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT domainWithoutWWWRFC(NULL, NULL, NULL);) 2025.10.23 23:49:16.408692 [ 30720 ] {362211f2-857c-4176-9f29-87f47511deed} TCPHandler: Code: 42. DB::Exception: Number of arguments for function domainWithoutWWWRFC doesn't match: passed 3, should be 1: In scope SELECT domainWithoutWWWRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:16.508506 [ 3894 ] {db6390b7-e9d3-4e94-b60d-f5c09a60314e} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:33416) (comment: 01045_zookeeper_system_mutations_with_parts_names.sh) (in query: DROP DATABASE IF EXISTS test_g3s9dkw3 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:49:16.512732 [ 3894 ] {db6390b7-e9d3-4e94-b60d-f5c09a60314e} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:16.526174 [ 30720 ] {e720d993-f21f-4200-abf0-9489b6590794} executeQuery: Code: 42. DB::Exception: Number of arguments for function dotProduct doesn't match: passed 3, should be 2: In scope SELECT dotProduct(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT dotProduct(NULL, NULL, NULL);) 2025.10.23 23:49:16.530256 [ 30720 ] {e720d993-f21f-4200-abf0-9489b6590794} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dotProduct doesn't match: passed 3, should be 2: In scope SELECT dotProduct(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:16.569514 [ 3450 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:16.575442 [ 4841 ] {d5788dcf-4b10-49c2-8d18-a162dbdcbf9c} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:33418) (comment: 01045_zookeeper_system_mutations_with_parts_names.sh) (in query: DROP DATABASE IF EXISTS test_g3s9dkw3 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:49:16.591772 [ 30720 ] {39826340-4d74-49a7-8cd2-522cbb8ed426} executeQuery: Code: 42. DB::Exception: Number of arguments for function dumpColumnStructure doesn't match: passed 3, should be 1: In scope SELECT dumpColumnStructure(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT dumpColumnStructure(NULL, NULL, NULL);) 2025.10.23 23:49:16.596525 [ 30720 ] {39826340-4d74-49a7-8cd2-522cbb8ed426} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dumpColumnStructure doesn't match: passed 3, should be 1: In scope SELECT dumpColumnStructure(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:16.614164 [ 4841 ] {d5788dcf-4b10-49c2-8d18-a162dbdcbf9c} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:16.699091 [ 3442 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:16.780200 [ 30720 ] {e2c86de0-3c16-4057-b7fb-b80d7c8ead48} executeQuery: Code: 42. DB::Exception: Number of arguments for function dynamicElement doesn't match: passed 3, should be 2: In scope SELECT dynamicElement(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT dynamicElement(NULL, NULL, NULL);) 2025.10.23 23:49:16.784100 [ 30720 ] {e2c86de0-3c16-4057-b7fb-b80d7c8ead48} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dynamicElement doesn't match: passed 3, should be 2: In scope SELECT dynamicElement(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:16.814603 [ 30720 ] {a53f657d-d63c-49ca-8f56-49ff563b8f27} executeQuery: Code: 42. DB::Exception: Number of arguments for function dynamicType doesn't match: passed 3, should be 1: In scope SELECT dynamicType(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT dynamicType(NULL, NULL, NULL);) 2025.10.23 23:49:16.817397 [ 30720 ] {a53f657d-d63c-49ca-8f56-49ff563b8f27} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dynamicType doesn't match: passed 3, should be 1: In scope SELECT dynamicType(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:16.837215 [ 3451 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:16.845223 [ 30720 ] {0a3eb157-3777-4dca-8d15-80c4b7c356da} executeQuery: Code: 42. DB::Exception: Number of arguments for function e doesn't match: passed 3, should be 0: In scope SELECT e(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT e(NULL, NULL, NULL);) 2025.10.23 23:49:16.848313 [ 30720 ] {0a3eb157-3777-4dca-8d15-80c4b7c356da} TCPHandler: Code: 42. DB::Exception: Number of arguments for function e doesn't match: passed 3, should be 0: In scope SELECT e(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:16.875188 [ 30720 ] {3c509298-8c03-480a-a00b-547b5c4e7451} executeQuery: Code: 42. DB::Exception: Number of arguments for function editDistance doesn't match: passed 3, should be 2: In scope SELECT editDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT editDistance(NULL, NULL, NULL);) 2025.10.23 23:49:16.877927 [ 30720 ] {3c509298-8c03-480a-a00b-547b5c4e7451} TCPHandler: Code: 42. DB::Exception: Number of arguments for function editDistance doesn't match: passed 3, should be 2: In scope SELECT editDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:17.015193 [ 30720 ] {84b8f560-dd5c-4d66-80d2-9cf132c56c41} executeQuery: Code: 42. DB::Exception: Number of arguments for function editDistanceUTF8 doesn't match: passed 3, should be 2: In scope SELECT editDistanceUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT editDistanceUTF8(NULL, NULL, NULL);) 2025.10.23 23:49:17.067033 [ 30720 ] {84b8f560-dd5c-4d66-80d2-9cf132c56c41} TCPHandler: Code: 42. DB::Exception: Number of arguments for function editDistanceUTF8 doesn't match: passed 3, should be 2: In scope SELECT editDistanceUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:17.105617 [ 30720 ] {8b989cf9-cbae-4e84-ba07-78609cab64c0} executeQuery: Code: 42. DB::Exception: Number of arguments for function empty doesn't match: passed 3, should be 1: In scope SELECT empty(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT empty(NULL, NULL, NULL);) 2025.10.23 23:49:17.108966 [ 30720 ] {8b989cf9-cbae-4e84-ba07-78609cab64c0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function empty doesn't match: passed 3, should be 1: In scope SELECT empty(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:17.149066 [ 30720 ] {626e3c42-2c31-48b1-83bf-809a9e6889c3} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayDate doesn't match: passed 3, should be 0: In scope SELECT emptyArrayDate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT emptyArrayDate(NULL, NULL, NULL);) 2025.10.23 23:49:17.153534 [ 30720 ] {626e3c42-2c31-48b1-83bf-809a9e6889c3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayDate doesn't match: passed 3, should be 0: In scope SELECT emptyArrayDate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:17.245613 [ 30720 ] {c63dd4e9-1200-49b7-9a93-857ad9b561d7} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayDateTime doesn't match: passed 3, should be 0: In scope SELECT emptyArrayDateTime(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT emptyArrayDateTime(NULL, NULL, NULL);) 2025.10.23 23:49:17.248647 [ 30720 ] {c63dd4e9-1200-49b7-9a93-857ad9b561d7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayDateTime doesn't match: passed 3, should be 0: In scope SELECT emptyArrayDateTime(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:17.276149 [ 30720 ] {ed4daf31-11c4-4652-981e-d78975f9b72c} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayFloat32 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayFloat32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT emptyArrayFloat32(NULL, NULL, NULL);) 2025.10.23 23:49:17.279214 [ 30720 ] {ed4daf31-11c4-4652-981e-d78975f9b72c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayFloat32 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayFloat32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:17.366828 [ 3474 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:17.366842 [ 3438 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:17.369083 [ 3432 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:17.383349 [ 30720 ] {edbd597d-5364-4919-9389-6397e4176e46} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayFloat64 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayFloat64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT emptyArrayFloat64(NULL, NULL, NULL);) 2025.10.23 23:49:17.387897 [ 30720 ] {edbd597d-5364-4919-9389-6397e4176e46} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayFloat64 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayFloat64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:17.425208 [ 30720 ] {58d56d33-2e52-41f7-82bc-5f74e54733dc} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt16 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayInt16(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT emptyArrayInt16(NULL, NULL, NULL);) 2025.10.23 23:49:17.480257 [ 30720 ] {58d56d33-2e52-41f7-82bc-5f74e54733dc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt16 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayInt16(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:17.509049 [ 30720 ] {6597b33f-c359-48a5-a3e1-73360f12e129} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt32 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayInt32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT emptyArrayInt32(NULL, NULL, NULL);) 2025.10.23 23:49:17.511910 [ 30720 ] {6597b33f-c359-48a5-a3e1-73360f12e129} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt32 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayInt32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:17.538182 [ 30720 ] {10aa776d-828b-4611-908a-33b8576bd35f} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt64 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayInt64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT emptyArrayInt64(NULL, NULL, NULL);) 2025.10.23 23:49:17.540929 [ 30720 ] {10aa776d-828b-4611-908a-33b8576bd35f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt64 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayInt64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:17.568341 [ 30720 ] {cef31bb3-83fd-4be7-942a-f41be5c90453} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt8 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayInt8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT emptyArrayInt8(NULL, NULL, NULL);) 2025.10.23 23:49:17.570450 [ 3425 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:17.571087 [ 30720 ] {cef31bb3-83fd-4be7-942a-f41be5c90453} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt8 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayInt8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:17.601381 [ 30720 ] {092f68b1-c9df-408e-9e2e-d0624b8f773c} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayString doesn't match: passed 3, should be 0: In scope SELECT emptyArrayString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT emptyArrayString(NULL, NULL, NULL);) 2025.10.23 23:49:17.603975 [ 30720 ] {092f68b1-c9df-408e-9e2e-d0624b8f773c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayString doesn't match: passed 3, should be 0: In scope SELECT emptyArrayString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:17.631685 [ 30720 ] {c899839b-9b5b-4af0-bebd-7d56599f27b7} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayToSingle doesn't match: passed 3, should be 1: In scope SELECT emptyArrayToSingle(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT emptyArrayToSingle(NULL, NULL, NULL);) 2025.10.23 23:49:17.675648 [ 30720 ] {c899839b-9b5b-4af0-bebd-7d56599f27b7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayToSingle doesn't match: passed 3, should be 1: In scope SELECT emptyArrayToSingle(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:17.700207 [ 3426 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:17.787181 [ 30720 ] {39a40065-ad29-49db-b266-3ab48a60d34e} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt16 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayUInt16(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT emptyArrayUInt16(NULL, NULL, NULL);) 2025.10.23 23:49:17.790059 [ 30720 ] {39a40065-ad29-49db-b266-3ab48a60d34e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt16 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayUInt16(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:17.817275 [ 30720 ] {b597c781-3116-4328-9b5d-b016985a9b0f} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt32 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayUInt32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT emptyArrayUInt32(NULL, NULL, NULL);) 2025.10.23 23:49:17.820058 [ 30720 ] {b597c781-3116-4328-9b5d-b016985a9b0f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt32 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayUInt32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:17.838427 [ 3413 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:17.847477 [ 30720 ] {cdf95d6f-44bf-46ac-a7ce-4e65cd423cbd} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt64 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayUInt64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT emptyArrayUInt64(NULL, NULL, NULL);) 2025.10.23 23:49:17.850483 [ 30720 ] {cdf95d6f-44bf-46ac-a7ce-4e65cd423cbd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt64 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayUInt64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:17.875910 [ 30720 ] {f36492b7-039b-4f11-a93d-c3e9e2269490} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt8 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayUInt8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT emptyArrayUInt8(NULL, NULL, NULL);) 2025.10.23 23:49:17.878700 [ 30720 ] {f36492b7-039b-4f11-a93d-c3e9e2269490} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt8 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayUInt8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:17.905426 [ 30720 ] {3325ee42-2224-45bb-b304-6b59c0073bae} executeQuery: Code: 42. DB::Exception: Number of arguments for function enabledProfiles doesn't match: passed 3, should be 0: In scope SELECT enabledProfiles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT enabledProfiles(NULL, NULL, NULL);) 2025.10.23 23:49:17.908620 [ 30720 ] {3325ee42-2224-45bb-b304-6b59c0073bae} TCPHandler: Code: 42. DB::Exception: Number of arguments for function enabledProfiles doesn't match: passed 3, should be 0: In scope SELECT enabledProfiles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:17.935329 [ 30720 ] {72757cc4-5db3-418d-ae27-c9d5f81ca5df} executeQuery: Code: 42. DB::Exception: Number of arguments for function enabledRoles doesn't match: passed 3, should be 0: In scope SELECT enabledRoles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT enabledRoles(NULL, NULL, NULL);) 2025.10.23 23:49:17.937917 [ 30720 ] {72757cc4-5db3-418d-ae27-c9d5f81ca5df} TCPHandler: Code: 42. DB::Exception: Number of arguments for function enabledRoles doesn't match: passed 3, should be 0: In scope SELECT enabledRoles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:17.964633 [ 30720 ] {c9290e71-e8af-4369-ac9c-575f07592dc2} executeQuery: Code: 42. DB::Exception: Number of arguments for function encodeURLComponent doesn't match: passed 3, should be 1: In scope SELECT encodeURLComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT encodeURLComponent(NULL, NULL, NULL);) 2025.10.23 23:49:17.967581 [ 30720 ] {c9290e71-e8af-4369-ac9c-575f07592dc2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function encodeURLComponent doesn't match: passed 3, should be 1: In scope SELECT encodeURLComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:18.094892 [ 30720 ] {e2832c83-08ce-4666-905c-37c6fb0852d9} executeQuery: Code: 42. DB::Exception: Number of arguments for function encodeURLFormComponent doesn't match: passed 3, should be 1: In scope SELECT encodeURLFormComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT encodeURLFormComponent(NULL, NULL, NULL);) 2025.10.23 23:49:18.097920 [ 30720 ] {e2832c83-08ce-4666-905c-37c6fb0852d9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function encodeURLFormComponent doesn't match: passed 3, should be 1: In scope SELECT encodeURLFormComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:18.122545 [ 30720 ] {79d32969-f9cd-4821-8f3a-2425f97bdc92} executeQuery: Code: 42. DB::Exception: Number of arguments for function encodeXMLComponent doesn't match: passed 3, should be 1: In scope SELECT encodeXMLComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT encodeXMLComponent(NULL, NULL, NULL);) 2025.10.23 23:49:18.125172 [ 30720 ] {79d32969-f9cd-4821-8f3a-2425f97bdc92} TCPHandler: Code: 42. DB::Exception: Number of arguments for function encodeXMLComponent doesn't match: passed 3, should be 1: In scope SELECT encodeXMLComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:18.221408 [ 30720 ] {0e6ad6b4-80dd-48da-8158-4a1c6aeb32a6} executeQuery: Code: 42. DB::Exception: Number of arguments for function endsWith doesn't match: passed 3, should be 2: In scope SELECT endsWith(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT endsWith(NULL, NULL, NULL);) 2025.10.23 23:49:18.224481 [ 30720 ] {0e6ad6b4-80dd-48da-8158-4a1c6aeb32a6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function endsWith doesn't match: passed 3, should be 2: In scope SELECT endsWith(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:18.251892 [ 30720 ] {e567a549-afa1-4a11-80c4-fcb3a132dad7} executeQuery: Code: 42. DB::Exception: Number of arguments for function endsWithUTF8 doesn't match: passed 3, should be 2: In scope SELECT endsWithUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT endsWithUTF8(NULL, NULL, NULL);) 2025.10.23 23:49:18.255301 [ 30720 ] {e567a549-afa1-4a11-80c4-fcb3a132dad7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function endsWithUTF8 doesn't match: passed 3, should be 2: In scope SELECT endsWithUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:18.367754 [ 3408 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:18.367831 [ 3399 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:18.370316 [ 3395 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:18.473428 [ 30720 ] {7e12fedf-31b3-4fd4-b53f-747ee533483c} executeQuery: Code: 42. DB::Exception: Number of arguments for function equals doesn't match: passed 3, should be 2: In scope SELECT equals(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT equals(NULL, NULL, NULL);) 2025.10.23 23:49:18.477930 [ 30720 ] {7e12fedf-31b3-4fd4-b53f-747ee533483c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function equals doesn't match: passed 3, should be 2: In scope SELECT equals(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:18.505848 [ 30720 ] {cc36e697-8448-4189-a5ea-2f9ba33a611a} executeQuery: Code: 42. DB::Exception: Number of arguments for function erf doesn't match: passed 3, should be 1: In scope SELECT erf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT erf(NULL, NULL, NULL);) 2025.10.23 23:49:18.508758 [ 30720 ] {cc36e697-8448-4189-a5ea-2f9ba33a611a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function erf doesn't match: passed 3, should be 1: In scope SELECT erf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:18.535501 [ 30720 ] {6d4cd5e0-8b19-482e-b835-029c44734ad5} executeQuery: Code: 42. DB::Exception: Number of arguments for function erfc doesn't match: passed 3, should be 1: In scope SELECT erfc(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT erfc(NULL, NULL, NULL);) 2025.10.23 23:49:18.538172 [ 30720 ] {6d4cd5e0-8b19-482e-b835-029c44734ad5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function erfc doesn't match: passed 3, should be 1: In scope SELECT erfc(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:18.564988 [ 30720 ] {9485b061-2aad-41ef-b9ca-de05818f4832} executeQuery: Code: 42. DB::Exception: Number of arguments for function errorCodeToName doesn't match: passed 3, should be 1: In scope SELECT errorCodeToName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT errorCodeToName(NULL, NULL, NULL);) 2025.10.23 23:49:18.567423 [ 30720 ] {9485b061-2aad-41ef-b9ca-de05818f4832} TCPHandler: Code: 42. DB::Exception: Number of arguments for function errorCodeToName doesn't match: passed 3, should be 1: In scope SELECT errorCodeToName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:18.571457 [ 3392 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:18.701174 [ 3394 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:18.827370 [ 30720 ] {4f74dd27-8d03-41e3-8b12-37df64cb4485} executeQuery: Code: 42. DB::Exception: Number of arguments for function exp doesn't match: passed 3, should be 1: In scope SELECT exp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT exp(NULL, NULL, NULL);) 2025.10.23 23:49:18.830968 [ 30720 ] {4f74dd27-8d03-41e3-8b12-37df64cb4485} TCPHandler: Code: 42. DB::Exception: Number of arguments for function exp doesn't match: passed 3, should be 1: In scope SELECT exp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:18.839535 [ 3386 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:18.971813 [ 30720 ] {d8e94345-44f9-47af-b126-c45b1a6283fa} executeQuery: Code: 42. DB::Exception: Number of arguments for function exp10 doesn't match: passed 3, should be 1: In scope SELECT exp10(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT exp10(NULL, NULL, NULL);) 2025.10.23 23:49:18.975811 [ 30720 ] {d8e94345-44f9-47af-b126-c45b1a6283fa} TCPHandler: Code: 42. DB::Exception: Number of arguments for function exp10 doesn't match: passed 3, should be 1: In scope SELECT exp10(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:19.139227 [ 30720 ] {41546fd2-e4af-4c7d-bc8d-1ce8fd5fc1b2} executeQuery: Code: 42. DB::Exception: Number of arguments for function exp2 doesn't match: passed 3, should be 1: In scope SELECT exp2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT exp2(NULL, NULL, NULL);) 2025.10.23 23:49:19.143103 [ 30720 ] {41546fd2-e4af-4c7d-bc8d-1ce8fd5fc1b2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function exp2 doesn't match: passed 3, should be 1: In scope SELECT exp2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:19.368695 [ 3374 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:19.368730 [ 3366 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:19.371133 [ 3360 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:19.515658 [ 30720 ] {a211d2ec-c641-4541-8eff-1edbcf66cf64} executeQuery: Code: 42. DB::Exception: Function exponentialTimeDecayedAvg takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT exponentialTimeDecayedAvg(NULL, NULL, NULL);) 2025.10.23 23:49:19.520826 [ 30720 ] {a211d2ec-c641-4541-8eff-1edbcf66cf64} TCPHandler: Code: 42. DB::Exception: Function exponentialTimeDecayedAvg takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:19.572808 [ 3358 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:19.702447 [ 3363 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:19.739374 [ 30720 ] {91f175e0-c710-448e-a674-ab09ff25da0f} executeQuery: Code: 42. DB::Exception: Function exponentialTimeDecayedCount takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT exponentialTimeDecayedCount(NULL, NULL, NULL);) 2025.10.23 23:49:19.743538 [ 30720 ] {91f175e0-c710-448e-a674-ab09ff25da0f} TCPHandler: Code: 42. DB::Exception: Function exponentialTimeDecayedCount takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:19.787956 [ 30720 ] {32764ecb-7e62-48df-b422-eeba396f6efe} executeQuery: Code: 42. DB::Exception: Function exponentialTimeDecayedMax takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT exponentialTimeDecayedMax(NULL, NULL, NULL);) 2025.10.23 23:49:19.791915 [ 30720 ] {32764ecb-7e62-48df-b422-eeba396f6efe} TCPHandler: Code: 42. DB::Exception: Function exponentialTimeDecayedMax takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:19.795642 [ 2903 ] {562183dd-d274-4aa0-b1c5-45b4a5b511b6} executeQuery: Code: 36. DB::Exception: The absolute data path should be inside `user_files_path`(/var/lib/clickhouse/user_files/). (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59574) (comment: 02126_fix_filelog.sh) (in query: create table file_log(k UInt8, v UInt8) engine=FileLog('/tmp/aaa.csv', 'CSV');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Storages/FileLog/StorageFileLog.cpp:161: DB::StorageFileLog::StorageFileLog(DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String const&, String const&, String const&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel) @ 0x0000000038e0b1ca 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel const&, void>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>&&, String const&, DB::LoadingStrictnessLevel const&) @ 0x0000000038e4de2a 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000038e34d6b 7. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x0000000038308626 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348e414c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:49:19.798556 [ 2903 ] {562183dd-d274-4aa0-b1c5-45b4a5b511b6} TCPHandler: Code: 36. DB::Exception: The absolute data path should be inside `user_files_path`(/var/lib/clickhouse/user_files/). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Storages/FileLog/StorageFileLog.cpp:161: DB::StorageFileLog::StorageFileLog(DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String const&, String const&, String const&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel) @ 0x0000000038e0b1ca 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel const&, void>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>&&, String const&, DB::LoadingStrictnessLevel const&) @ 0x0000000038e4de2a 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000038e34d6b 7. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x0000000038308626 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348e414c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:49:19.840744 [ 3373 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:19.888558 [ 30720 ] {58164c37-5fd2-4ce1-b1e8-89a83bc197f2} executeQuery: Code: 42. DB::Exception: Function exponentialTimeDecayedSum takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT exponentialTimeDecayedSum(NULL, NULL, NULL);) 2025.10.23 23:49:19.891342 [ 30720 ] {58164c37-5fd2-4ce1-b1e8-89a83bc197f2} TCPHandler: Code: 42. DB::Exception: Function exponentialTimeDecayedSum takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:20.017746 [ 30720 ] {2ce4d521-e6e9-473a-8d79-ad5207b06043} executeQuery: Code: 42. DB::Exception: Number of arguments for function extract doesn't match: passed 3, should be 2: In scope SELECT extract(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT extract(NULL, NULL, NULL);) 2025.10.23 23:49:20.021799 [ 30720 ] {2ce4d521-e6e9-473a-8d79-ad5207b06043} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extract doesn't match: passed 3, should be 2: In scope SELECT extract(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:20.067625 [ 30720 ] {957ccb5d-bea0-4c0d-8878-1a252ae233e2} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractAll doesn't match: passed 3, should be 2: In scope SELECT extractAll(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT extractAll(NULL, NULL, NULL);) 2025.10.23 23:49:20.071541 [ 30720 ] {957ccb5d-bea0-4c0d-8878-1a252ae233e2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractAll doesn't match: passed 3, should be 2: In scope SELECT extractAll(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:20.214984 [ 30720 ] {93cdd457-2719-46a9-aa2a-eb27e3225dc7} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsVertical doesn't match: passed 3, should be 2: In scope SELECT extractAllGroups(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT extractAllGroups(NULL, NULL, NULL);) 2025.10.23 23:49:20.218451 [ 30720 ] {93cdd457-2719-46a9-aa2a-eb27e3225dc7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsVertical doesn't match: passed 3, should be 2: In scope SELECT extractAllGroups(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:20.246844 [ 30720 ] {cb80c827-6ad7-4f01-bf6a-5f2bbe14aa47} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsHorizontal doesn't match: passed 3, should be 2: In scope SELECT extractAllGroupsHorizontal(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT extractAllGroupsHorizontal(NULL, NULL, NULL);) 2025.10.23 23:49:20.249580 [ 30720 ] {cb80c827-6ad7-4f01-bf6a-5f2bbe14aa47} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsHorizontal doesn't match: passed 3, should be 2: In scope SELECT extractAllGroupsHorizontal(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:20.369661 [ 3339 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:20.369662 [ 3347 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:20.373664 [ 30720 ] {92c7bf98-a3e2-4a41-b0df-07227e04cd7d} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsVertical doesn't match: passed 3, should be 2: In scope SELECT extractAllGroupsVertical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT extractAllGroupsVertical(NULL, NULL, NULL);) 2025.10.23 23:49:20.376334 [ 30720 ] {92c7bf98-a3e2-4a41-b0df-07227e04cd7d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsVertical doesn't match: passed 3, should be 2: In scope SELECT extractAllGroupsVertical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:20.413954 [ 3344 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:20.447817 [ 30720 ] {e7ade177-9ab3-4a32-a892-9de82f5e061e} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractGroups doesn't match: passed 3, should be 2: In scope SELECT extractGroups(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT extractGroups(NULL, NULL, NULL);) 2025.10.23 23:49:20.450594 [ 30720 ] {e7ade177-9ab3-4a32-a892-9de82f5e061e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractGroups doesn't match: passed 3, should be 2: In scope SELECT extractGroups(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:20.523094 [ 2903 ] {32742c2b-3d81-49c7-9c84-2f1649c5ce12} executeQuery: Code: 36. DB::Exception: The absolute data path should be inside `user_files_path`(/var/lib/clickhouse/user_files/). (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59578) (comment: 02126_fix_filelog.sh) (in query: create table file_log(k UInt8, v UInt8) engine=FileLog('/tmp/aaa.csv', 'CSV');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Storages/FileLog/StorageFileLog.cpp:161: DB::StorageFileLog::StorageFileLog(DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String const&, String const&, String const&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel) @ 0x0000000038e0b1ca 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel const&, void>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>&&, String const&, DB::LoadingStrictnessLevel const&) @ 0x0000000038e4de2a 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000038e34d6b 7. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x0000000038308626 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348e414c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:49:20.552097 [ 2903 ] {32742c2b-3d81-49c7-9c84-2f1649c5ce12} TCPHandler: Code: 36. DB::Exception: The absolute data path should be inside `user_files_path`(/var/lib/clickhouse/user_files/). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Storages/FileLog/StorageFileLog.cpp:161: DB::StorageFileLog::StorageFileLog(DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String const&, String const&, String const&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel) @ 0x0000000038e0b1ca 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel const&, void>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>&&, String const&, DB::LoadingStrictnessLevel const&) @ 0x0000000038e4de2a 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000038e34d6b 7. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x0000000038308626 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348e414c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:49:20.574241 [ 3365 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:20.632722 [ 30720 ] {dac6c475-4ebb-41c2-83eb-1c648ea0048d} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractTextFromHTML doesn't match: passed 3, should be 1: In scope SELECT extractTextFromHTML(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT extractTextFromHTML(NULL, NULL, NULL);) 2025.10.23 23:49:20.635333 [ 30720 ] {dac6c475-4ebb-41c2-83eb-1c648ea0048d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractTextFromHTML doesn't match: passed 3, should be 1: In scope SELECT extractTextFromHTML(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:20.662062 [ 30720 ] {c7ef0d3d-66b9-4de0-92a4-b13f5b053441} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractURLParameter doesn't match: passed 3, should be 2: In scope SELECT extractURLParameter(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT extractURLParameter(NULL, NULL, NULL);) 2025.10.23 23:49:20.664602 [ 30720 ] {c7ef0d3d-66b9-4de0-92a4-b13f5b053441} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractURLParameter doesn't match: passed 3, should be 2: In scope SELECT extractURLParameter(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:20.690603 [ 30720 ] {6cde18e9-7b3c-484d-8730-11a01f300c76} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractURLParameterNames doesn't match: passed 3, should be 1: In scope SELECT extractURLParameterNames(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT extractURLParameterNames(NULL, NULL, NULL);) 2025.10.23 23:49:20.693248 [ 30720 ] {6cde18e9-7b3c-484d-8730-11a01f300c76} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractURLParameterNames doesn't match: passed 3, should be 1: In scope SELECT extractURLParameterNames(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:20.703442 [ 3334 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:20.741661 [ 30720 ] {e6bf2122-4856-4b0c-8837-0a614682e04e} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractURLParameters doesn't match: passed 3, should be 1: In scope SELECT extractURLParameters(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT extractURLParameters(NULL, NULL, NULL);) 2025.10.23 23:49:20.744495 [ 30720 ] {e6bf2122-4856-4b0c-8837-0a614682e04e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractURLParameters doesn't match: passed 3, should be 1: In scope SELECT extractURLParameters(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:20.771308 [ 30720 ] {4faea450-7e01-4a29-8d74-f172442fdbb6} executeQuery: Code: 42. DB::Exception: Number of arguments for function factorial doesn't match: passed 3, should be 1: In scope SELECT factorial(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT factorial(NULL, NULL, NULL);) 2025.10.23 23:49:20.773989 [ 30720 ] {4faea450-7e01-4a29-8d74-f172442fdbb6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function factorial doesn't match: passed 3, should be 1: In scope SELECT factorial(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:20.841748 [ 3327 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:20.970958 [ 30720 ] {364948b9-175c-4cf1-9e13-131b9697f6c7} executeQuery: Code: 42. DB::Exception: Number of arguments for function file doesn't match: passed 3, should be 1 or 2: In scope SELECT file(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT file(NULL, NULL, NULL);) 2025.10.23 23:49:20.973735 [ 30720 ] {364948b9-175c-4cf1-9e13-131b9697f6c7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function file doesn't match: passed 3, should be 1 or 2: In scope SELECT file(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:21.334081 [ 2903 ] {ac249e07-3fd6-48e6-a76c-127d1bdde76e} executeQuery: Code: 36. DB::Exception: The absolute data path should be inside `user_files_path`(/var/lib/clickhouse/user_files/). (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59594) (comment: 02126_fix_filelog.sh) (in query: create table file_log(k UInt8, v UInt8) engine=FileLog('/tmp/aaa.csv', 'CSV');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Storages/FileLog/StorageFileLog.cpp:161: DB::StorageFileLog::StorageFileLog(DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String const&, String const&, String const&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel) @ 0x0000000038e0b1ca 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel const&, void>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>&&, String const&, DB::LoadingStrictnessLevel const&) @ 0x0000000038e4de2a 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000038e34d6b 7. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x0000000038308626 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348e414c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:49:21.337070 [ 2903 ] {ac249e07-3fd6-48e6-a76c-127d1bdde76e} TCPHandler: Code: 36. DB::Exception: The absolute data path should be inside `user_files_path`(/var/lib/clickhouse/user_files/). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Storages/FileLog/StorageFileLog.cpp:161: DB::StorageFileLog::StorageFileLog(DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String const&, String const&, String const&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel) @ 0x0000000038e0b1ca 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel const&, void>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>&&, String const&, DB::LoadingStrictnessLevel const&) @ 0x0000000038e4de2a 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000038e34d6b 7. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x0000000038308626 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348e414c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:49:21.344138 [ 30720 ] {b1bb9e30-39ef-4e50-99bd-f1c9f3e5af70} executeQuery: Code: 42. DB::Exception: Number of arguments for function finalizeAggregation doesn't match: passed 3, should be 1: In scope SELECT finalizeAggregation(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT finalizeAggregation(NULL, NULL, NULL);) 2025.10.23 23:49:21.346672 [ 30720 ] {b1bb9e30-39ef-4e50-99bd-f1c9f3e5af70} TCPHandler: Code: 42. DB::Exception: Number of arguments for function finalizeAggregation doesn't match: passed 3, should be 1: In scope SELECT finalizeAggregation(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:21.370455 [ 3316 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:21.370607 [ 3342 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:21.372519 [ 30720 ] {82ac1c28-f2b0-4c93-8892-2be9967c21b3} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstLine doesn't match: passed 3, should be 1: In scope SELECT firstLine(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT firstLine(NULL, NULL, NULL);) 2025.10.23 23:49:21.375210 [ 30720 ] {82ac1c28-f2b0-4c93-8892-2be9967c21b3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstLine doesn't match: passed 3, should be 1: In scope SELECT firstLine(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:21.401962 [ 30720 ] {4937800c-3e08-4291-bcfd-e32cab485586} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomain doesn't match: passed 3, should be 1: In scope SELECT firstSignificantSubdomain(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT firstSignificantSubdomain(NULL, NULL, NULL);) 2025.10.23 23:49:21.405223 [ 30720 ] {4937800c-3e08-4291-bcfd-e32cab485586} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomain doesn't match: passed 3, should be 1: In scope SELECT firstSignificantSubdomain(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:21.414928 [ 3311 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:21.527528 [ 30720 ] {84950c4e-c13a-4164-9597-950788e31c79} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainCustom doesn't match: passed 3, should be 2: In scope SELECT firstSignificantSubdomainCustom(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT firstSignificantSubdomainCustom(NULL, NULL, NULL);) 2025.10.23 23:49:21.532180 [ 30720 ] {84950c4e-c13a-4164-9597-950788e31c79} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainCustom doesn't match: passed 3, should be 2: In scope SELECT firstSignificantSubdomainCustom(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:21.573832 [ 30720 ] {22cc2859-2386-44f7-9933-85b1dce7b0e3} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainCustomRFC doesn't match: passed 3, should be 2: In scope SELECT firstSignificantSubdomainCustomRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT firstSignificantSubdomainCustomRFC(NULL, NULL, NULL);) 2025.10.23 23:49:21.575528 [ 3317 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:21.577886 [ 30720 ] {22cc2859-2386-44f7-9933-85b1dce7b0e3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainCustomRFC doesn't match: passed 3, should be 2: In scope SELECT firstSignificantSubdomainCustomRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:21.704366 [ 3307 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:21.743378 [ 30720 ] {7698a00e-96c5-4191-bacc-8002a125c5e0} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainRFC doesn't match: passed 3, should be 1: In scope SELECT firstSignificantSubdomainRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT firstSignificantSubdomainRFC(NULL, NULL, NULL);) 2025.10.23 23:49:21.746040 [ 30720 ] {7698a00e-96c5-4191-bacc-8002a125c5e0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainRFC doesn't match: passed 3, should be 1: In scope SELECT firstSignificantSubdomainRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:21.842685 [ 3306 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:21.901739 [ 29264 ] {1629f0af-998e-463d-b81e-7e60c377624d} executeQuery: Code: 36. DB::Exception: Primary key or secondary index contains a duplicate expression. To suppress this exception, rerun the command with setting 'allow_suspicious_indices = 1'. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59568) (comment: 02710_allow_suspicious_indices.sql) (in query: CREATE TABLE tbl (`id` UInt32) ENGINE = MergeTree ORDER BY (id + 1, id + 1) SETTINGS index_granularity = 14225, min_bytes_for_wide_part = 224024538, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 447525591, compact_parts_max_granules_to_buffer = 146, compact_parts_merge_max_bytes_to_prefetch_part = 377068, merge_max_block_size = 14061, old_parts_lifetime = 33., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 3092168128, index_granularity_bytes = 1847077, concurrent_part_removal_threshold = 81, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 35837, primary_key_compress_block_size = 49044), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:207: DB::checkSuspiciousIndices(DB::ASTFunction const*) @ 0x00000000396dcccb 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, std::shared_ptr) const @ 0x00000000396d604e 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x00000000396c151d 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x00000000396bdea5 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:96: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000003a2e5c10 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a2e404f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2d3063 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7b27a 12. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x0000000038308626 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348e414c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:49:21.903311 [ 30720 ] {0909ee95-a041-4f98-a4f6-64934ccdd3ca} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT first_value_respect_nulls(NULL, NULL, NULL);) 2025.10.23 23:49:21.903319 [ 29264 ] {1629f0af-998e-463d-b81e-7e60c377624d} TCPHandler: Code: 36. DB::Exception: Primary key or secondary index contains a duplicate expression. To suppress this exception, rerun the command with setting 'allow_suspicious_indices = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:207: DB::checkSuspiciousIndices(DB::ASTFunction const*) @ 0x00000000396dcccb 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, std::shared_ptr) const @ 0x00000000396d604e 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x00000000396c151d 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x00000000396bdea5 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:96: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000003a2e5c10 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a2e404f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2d3063 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7b27a 12. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x0000000038308626 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348e414c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:49:21.906062 [ 30720 ] {0909ee95-a041-4f98-a4f6-64934ccdd3ca} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:22.041770 [ 30720 ] {4ea1faa9-0849-4190-900c-d1d4dc6c2dd9} executeQuery: Code: 43. DB::Exception: First argument (trace) for function flameGraph must be Array(UInt64), but it has type Nullable(Nothing). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT flameGraph(NULL, NULL, NULL);) 2025.10.23 23:49:22.044587 [ 30720 ] {4ea1faa9-0849-4190-900c-d1d4dc6c2dd9} TCPHandler: Code: 43. DB::Exception: First argument (trace) for function flameGraph must be Array(UInt64), but it has type Nullable(Nothing). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:49:22.082603 [ 30720 ] {35b9c39a-8cf0-43fd-b6b7-d3e173dc9af0} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayFlatten doesn't match: passed 3, should be 1: In scope SELECT flatten(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT flatten(NULL, NULL, NULL);) 2025.10.23 23:49:22.086584 [ 30720 ] {35b9c39a-8cf0-43fd-b6b7-d3e173dc9af0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayFlatten doesn't match: passed 3, should be 1: In scope SELECT flatten(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:22.127482 [ 30720 ] {15a9458e-b0fd-4922-b60e-3e8ec30215a7} executeQuery: Code: 42. DB::Exception: Number of arguments for function flattenTuple doesn't match: passed 3, should be 1: In scope SELECT flattenTuple(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT flattenTuple(NULL, NULL, NULL);) 2025.10.23 23:49:22.131198 [ 30720 ] {15a9458e-b0fd-4922-b60e-3e8ec30215a7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function flattenTuple doesn't match: passed 3, should be 1: In scope SELECT flattenTuple(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:22.371496 [ 3289 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:22.372070 [ 3286 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:22.416199 [ 3285 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:22.576718 [ 3284 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:22.705362 [ 3279 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:22.719231 [ 30720 ] {50c69622-c5b1-42bb-bb28-1cdbdcbb4f5b} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatQuery doesn't match: passed 3, should be 1: In scope SELECT formatQuery(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT formatQuery(NULL, NULL, NULL);) 2025.10.23 23:49:22.721895 [ 30720 ] {50c69622-c5b1-42bb-bb28-1cdbdcbb4f5b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatQuery doesn't match: passed 3, should be 1: In scope SELECT formatQuery(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:22.792406 [ 30720 ] {30eb8c47-5577-402c-83c0-7265ca150f03} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatQueryOrNull doesn't match: passed 3, should be 1: In scope SELECT formatQueryOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT formatQueryOrNull(NULL, NULL, NULL);) 2025.10.23 23:49:22.795624 [ 30720 ] {30eb8c47-5577-402c-83c0-7265ca150f03} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatQueryOrNull doesn't match: passed 3, should be 1: In scope SELECT formatQueryOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:22.822914 [ 30720 ] {488c969f-4c9e-4587-8aae-c192042f126a} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatQuerySingleLine doesn't match: passed 3, should be 1: In scope SELECT formatQuerySingleLine(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT formatQuerySingleLine(NULL, NULL, NULL);) 2025.10.23 23:49:22.825865 [ 30720 ] {488c969f-4c9e-4587-8aae-c192042f126a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatQuerySingleLine doesn't match: passed 3, should be 1: In scope SELECT formatQuerySingleLine(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:22.844261 [ 3281 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:22.851348 [ 30720 ] {f71cbfc2-d714-4a11-843d-ebdc492aa525} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatQuerySingleLineOrNull doesn't match: passed 3, should be 1: In scope SELECT formatQuerySingleLineOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT formatQuerySingleLineOrNull(NULL, NULL, NULL);) 2025.10.23 23:49:22.854103 [ 30720 ] {f71cbfc2-d714-4a11-843d-ebdc492aa525} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatQuerySingleLineOrNull doesn't match: passed 3, should be 1: In scope SELECT formatQuerySingleLineOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:22.877559 [ 30720 ] {8c139da5-635a-4cc8-b4c4-030867b0d744} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatReadableDecimalSize doesn't match: passed 3, should be 1: In scope SELECT formatReadableDecimalSize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT formatReadableDecimalSize(NULL, NULL, NULL);) 2025.10.23 23:49:22.880022 [ 30720 ] {8c139da5-635a-4cc8-b4c4-030867b0d744} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatReadableDecimalSize doesn't match: passed 3, should be 1: In scope SELECT formatReadableDecimalSize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:22.905081 [ 30720 ] {3379d99b-292d-4c41-88ea-8e4c69da571f} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatReadableQuantity doesn't match: passed 3, should be 1: In scope SELECT formatReadableQuantity(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT formatReadableQuantity(NULL, NULL, NULL);) 2025.10.23 23:49:22.907623 [ 30720 ] {3379d99b-292d-4c41-88ea-8e4c69da571f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatReadableQuantity doesn't match: passed 3, should be 1: In scope SELECT formatReadableQuantity(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:22.935056 [ 30720 ] {c31a8681-a932-44bb-ab18-eb974e8340df} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatReadableSize doesn't match: passed 3, should be 1: In scope SELECT formatReadableSize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT formatReadableSize(NULL, NULL, NULL);) 2025.10.23 23:49:22.937454 [ 30720 ] {c31a8681-a932-44bb-ab18-eb974e8340df} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatReadableSize doesn't match: passed 3, should be 1: In scope SELECT formatReadableSize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:23.062825 [ 30720 ] {f2081f57-0a04-4bd3-a89c-d7bb5f302d5e} executeQuery: Code: 43. DB::Exception: First argument to formatRow must be a format name: In scope SELECT formatRow(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT formatRow(NULL, NULL, NULL);) 2025.10.23 23:49:23.065952 [ 30720 ] {f2081f57-0a04-4bd3-a89c-d7bb5f302d5e} TCPHandler: Code: 43. DB::Exception: First argument to formatRow must be a format name: In scope SELECT formatRow(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:49:23.109716 [ 30720 ] {2f8995ef-82b6-48f2-bd47-eac86956b62b} executeQuery: Code: 43. DB::Exception: First argument to formatRowNoNewline must be a format name: In scope SELECT formatRowNoNewline(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT formatRowNoNewline(NULL, NULL, NULL);) 2025.10.23 23:49:23.114135 [ 30720 ] {2f8995ef-82b6-48f2-bd47-eac86956b62b} TCPHandler: Code: 43. DB::Exception: First argument to formatRowNoNewline must be a format name: In scope SELECT formatRowNoNewline(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:49:23.156485 [ 30720 ] {0e6da674-d97c-4e6e-bf48-2afc61ae380f} executeQuery: Code: 42. DB::Exception: Number of arguments for function fragment doesn't match: passed 3, should be 1: In scope SELECT fragment(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT fragment(NULL, NULL, NULL);) 2025.10.23 23:49:23.160491 [ 30720 ] {0e6da674-d97c-4e6e-bf48-2afc61ae380f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fragment doesn't match: passed 3, should be 1: In scope SELECT fragment(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:23.192767 [ 30720 ] {a84f4bc0-9f0a-4981-8fa6-ee3aee484595} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero doesn't match: passed 3, should be 1: In scope SELECT fromDaysSinceYearZero(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT fromDaysSinceYearZero(NULL, NULL, NULL);) 2025.10.23 23:49:23.205653 [ 30720 ] {a84f4bc0-9f0a-4981-8fa6-ee3aee484595} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero doesn't match: passed 3, should be 1: In scope SELECT fromDaysSinceYearZero(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:23.340498 [ 30720 ] {f72fae39-c150-411a-b341-6c7623b668a8} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero32 doesn't match: passed 3, should be 1: In scope SELECT fromDaysSinceYearZero32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT fromDaysSinceYearZero32(NULL, NULL, NULL);) 2025.10.23 23:49:23.344433 [ 30720 ] {f72fae39-c150-411a-b341-6c7623b668a8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero32 doesn't match: passed 3, should be 1: In scope SELECT fromDaysSinceYearZero32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:23.372800 [ 3261 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:23.373232 [ 3274 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:23.384709 [ 30720 ] {020a4697-6d0a-46ce-858a-f05b9c8f4330} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromModifiedJulianDay doesn't match: passed 3, should be 1: In scope SELECT fromModifiedJulianDay(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT fromModifiedJulianDay(NULL, NULL, NULL);) 2025.10.23 23:49:23.388466 [ 30720 ] {020a4697-6d0a-46ce-858a-f05b9c8f4330} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromModifiedJulianDay doesn't match: passed 3, should be 1: In scope SELECT fromModifiedJulianDay(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:23.417406 [ 3264 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:23.577761 [ 3252 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:23.587089 [ 30720 ] {3ff66569-14a5-464d-bd99-72ccbdff80fc} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromModifiedJulianDayOrNull doesn't match: passed 3, should be 1: In scope SELECT fromModifiedJulianDayOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT fromModifiedJulianDayOrNull(NULL, NULL, NULL);) 2025.10.23 23:49:23.640094 [ 30720 ] {3ff66569-14a5-464d-bd99-72ccbdff80fc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromModifiedJulianDayOrNull doesn't match: passed 3, should be 1: In scope SELECT fromModifiedJulianDayOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:23.676102 [ 30720 ] {b65f8007-20cf-4805-a632-1aa5d842e54b} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromUTCTimestamp doesn't match: passed 3, should be 2: In scope SELECT fromUTCTimestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT fromUTCTimestamp(NULL, NULL, NULL);) 2025.10.23 23:49:23.678891 [ 30720 ] {b65f8007-20cf-4805-a632-1aa5d842e54b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromUTCTimestamp doesn't match: passed 3, should be 2: In scope SELECT fromUTCTimestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:23.707045 [ 3251 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:23.845666 [ 3242 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:24.085722 [ 30720 ] {93825938-8129-4f03-84be-87e56d252ce3} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromUTCTimestamp doesn't match: passed 3, should be 2: In scope SELECT from_utc_timestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT from_utc_timestamp(NULL, NULL, NULL);) 2025.10.23 23:49:24.088376 [ 30720 ] {93825938-8129-4f03-84be-87e56d252ce3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromUTCTimestamp doesn't match: passed 3, should be 2: In scope SELECT from_utc_timestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:24.114387 [ 30720 ] {3c6c3de9-68c8-4f42-945f-8731f82d0247} executeQuery: Code: 42. DB::Exception: Number of arguments for function FQDN doesn't match: passed 3, should be 0: In scope SELECT fullHostName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT fullHostName(NULL, NULL, NULL);) 2025.10.23 23:49:24.117112 [ 30720 ] {3c6c3de9-68c8-4f42-945f-8731f82d0247} TCPHandler: Code: 42. DB::Exception: Number of arguments for function FQDN doesn't match: passed 3, should be 0: In scope SELECT fullHostName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:24.123578 [ 2903 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x00000000315a10ad 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159da2f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b6b4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa269fb 10. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:24.143076 [ 30720 ] {e86112e1-587d-4802-b549-b9fba02c5b63} executeQuery: Code: 42. DB::Exception: Number of arguments for function fuzzBits doesn't match: passed 3, should be 2: In scope SELECT fuzzBits(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT fuzzBits(NULL, NULL, NULL);) 2025.10.23 23:49:24.201399 [ 30720 ] {e86112e1-587d-4802-b549-b9fba02c5b63} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fuzzBits doesn't match: passed 3, should be 2: In scope SELECT fuzzBits(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:24.363639 [ 30720 ] {71e0212a-6fd6-4653-b1c0-268b7d2078d4} executeQuery: Code: 42. DB::Exception: Number of arguments for function gcd doesn't match: passed 3, should be 2: In scope SELECT gcd(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT gcd(NULL, NULL, NULL);) 2025.10.23 23:49:24.366323 [ 30720 ] {71e0212a-6fd6-4653-b1c0-268b7d2078d4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function gcd doesn't match: passed 3, should be 2: In scope SELECT gcd(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:24.373829 [ 3239 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:24.374157 [ 3226 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:24.401446 [ 30720 ] {9d6f032c-2799-4f72-a062-ccd38400e53e} executeQuery: Code: 42. DB::Exception: Number of arguments for function generateRandomStructure doesn't match: passed 3, expected from 0 to 2: In scope SELECT generateRandomStructure(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT generateRandomStructure(NULL, NULL, NULL);) 2025.10.23 23:49:24.404202 [ 30720 ] {9d6f032c-2799-4f72-a062-ccd38400e53e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function generateRandomStructure doesn't match: passed 3, expected from 0 to 2: In scope SELECT generateRandomStructure(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:24.418601 [ 3234 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:24.485074 [ 30720 ] {bbf801d6-7903-4960-886f-762e37dc9b80} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'generateSnowflakeID'. Expected 2 optional arguments, got 3 arguments: In scope SELECT generateSnowflakeID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT generateSnowflakeID(NULL, NULL, NULL);) 2025.10.23 23:49:24.488183 [ 30720 ] {bbf801d6-7903-4960-886f-762e37dc9b80} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'generateSnowflakeID'. Expected 2 optional arguments, got 3 arguments: In scope SELECT generateSnowflakeID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:24.574764 [ 30720 ] {186de431-6e47-4ef4-b09f-8ca5f2ea0f74} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'generateUUIDv4'. Expected 1 optional argument, got 3 arguments: In scope SELECT generateUUIDv4(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT generateUUIDv4(NULL, NULL, NULL);) 2025.10.23 23:49:24.577606 [ 30720 ] {186de431-6e47-4ef4-b09f-8ca5f2ea0f74} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'generateUUIDv4'. Expected 1 optional argument, got 3 arguments: In scope SELECT generateUUIDv4(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:24.579056 [ 3245 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:24.609845 [ 29264 ] {30c695c7-9311-48ab-acf9-db6871edaaf2} executeQuery: Code: 36. DB::Exception: Primary key or secondary index contains a duplicate expression. To suppress this exception, rerun the command with setting 'allow_suspicious_indices = 1'. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59568) (comment: 02710_allow_suspicious_indices.sql) (in query: CREATE TABLE tbl (`id` UInt32, INDEX idx (id + 1, id + 1) TYPE minmax GRANULARITY 1) ENGINE = MergeTree ORDER BY id SETTINGS index_granularity = 14225, min_bytes_for_wide_part = 224024538, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 447525591, compact_parts_max_granules_to_buffer = 146, compact_parts_merge_max_bytes_to_prefetch_part = 377068, merge_max_block_size = 14061, old_parts_lifetime = 33., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 3092168128, index_granularity_bytes = 1847077, concurrent_part_removal_threshold = 81, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 35837, primary_key_compress_block_size = 49044), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:207: DB::checkSuspiciousIndices(DB::ASTFunction const*) @ 0x00000000396dcccb 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, std::shared_ptr) const @ 0x00000000396d8f9d 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x00000000396c151d 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x00000000396bdea5 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:96: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000003a2e5c10 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a2e404f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2d3063 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7b27a 12. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x0000000038308626 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348e414c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:49:24.611572 [ 29264 ] {30c695c7-9311-48ab-acf9-db6871edaaf2} TCPHandler: Code: 36. DB::Exception: Primary key or secondary index contains a duplicate expression. To suppress this exception, rerun the command with setting 'allow_suspicious_indices = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:207: DB::checkSuspiciousIndices(DB::ASTFunction const*) @ 0x00000000396dcccb 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, std::shared_ptr) const @ 0x00000000396d8f9d 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x00000000396c151d 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x00000000396bdea5 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:96: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000003a2e5c10 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a2e404f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2d3063 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7b27a 12. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x0000000038308626 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348e414c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:49:24.612961 [ 30720 ] {4c453e11-2622-46c1-987a-4ab67e58364a} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'generateUUIDv7'. Expected 1 optional argument, got 3 arguments: In scope SELECT generateUUIDv7(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT generateUUIDv7(NULL, NULL, NULL);) 2025.10.23 23:49:24.617289 [ 30720 ] {4c453e11-2622-46c1-987a-4ab67e58364a} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'generateUUIDv7'. Expected 1 optional argument, got 3 arguments: In scope SELECT generateUUIDv7(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:24.706800 [ 30720 ] {330df2a1-3cf3-483f-9f99-ebe4b3c9fc61} executeQuery: Code: 42. DB::Exception: Number of arguments for function geoDistance doesn't match: passed 3, should be 4: In scope SELECT geoDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT geoDistance(NULL, NULL, NULL);) 2025.10.23 23:49:24.708450 [ 3218 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:24.712020 [ 30720 ] {330df2a1-3cf3-483f-9f99-ebe4b3c9fc61} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geoDistance doesn't match: passed 3, should be 4: In scope SELECT geoDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:24.811289 [ 30720 ] {575d78a4-0a71-4892-9c48-03c1436b2ab0} executeQuery: Code: 42. DB::Exception: Number of arguments for function geoToS2 doesn't match: passed 3, should be 2: In scope SELECT geoToS2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT geoToS2(NULL, NULL, NULL);) 2025.10.23 23:49:24.814415 [ 30720 ] {575d78a4-0a71-4892-9c48-03c1436b2ab0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geoToS2 doesn't match: passed 3, should be 2: In scope SELECT geoToS2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:24.846870 [ 3221 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:24.915370 [ 29264 ] {a43c106f-f6f0-442b-a307-ca6a577a0cec} executeQuery: Code: 57. DB::Exception: Table test_1.tbl already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59568) (comment: 02710_allow_suspicious_indices.sql) (in query: CREATE TABLE tbl (`id1` UInt32) ENGINE = MergeTree ORDER BY id1 SETTINGS index_granularity = 14225, min_bytes_for_wide_part = 224024538, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 447525591, compact_parts_max_granules_to_buffer = 146, compact_parts_merge_max_bytes_to_prefetch_part = 377068, merge_max_block_size = 14061, old_parts_lifetime = 33., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 3092168128, index_granularity_bytes = 1847077, concurrent_part_removal_threshold = 81, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 35837, primary_key_compress_block_size = 49044), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:49:24.916744 [ 30720 ] {41db3743-06ac-4a9d-b471-e964ca2d437e} executeQuery: Code: 42. DB::Exception: Number of arguments for function geohashDecode doesn't match: passed 3, should be 1: In scope SELECT geohashDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT geohashDecode(NULL, NULL, NULL);) 2025.10.23 23:49:24.917647 [ 29264 ] {a43c106f-f6f0-442b-a307-ca6a577a0cec} TCPHandler: Code: 57. DB::Exception: Table test_1.tbl already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:49:24.919763 [ 30720 ] {41db3743-06ac-4a9d-b471-e964ca2d437e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geohashDecode doesn't match: passed 3, should be 1: In scope SELECT geohashDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:25.013421 [ 30720 ] {b43d4cdd-fd0f-40ab-b874-365e7667d37b} executeQuery: Code: 42. DB::Exception: Number of arguments for function geohashesInBox doesn't match: passed 3, should be 5: In scope SELECT geohashesInBox(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT geohashesInBox(NULL, NULL, NULL);) 2025.10.23 23:49:25.015664 [ 30720 ] {b43d4cdd-fd0f-40ab-b874-365e7667d37b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geohashesInBox doesn't match: passed 3, should be 5: In scope SELECT geohashesInBox(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:25.040500 [ 30720 ] {856e9552-3d06-4ba7-87f0-d0ef7e97c6eb} executeQuery: Code: 446. DB::Exception: The function getClientHTTPHeader requires setting `allow_get_client_http_header` to be enabled. (FUNCTION_NOT_ALLOWED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT getClientHTTPHeader(NULL, NULL, NULL);) 2025.10.23 23:49:25.042602 [ 30720 ] {856e9552-3d06-4ba7-87f0-d0ef7e97c6eb} TCPHandler: Code: 446. DB::Exception: The function getClientHTTPHeader requires setting `allow_get_client_http_header` to be enabled. (FUNCTION_NOT_ALLOWED) 2025.10.23 23:49:25.066009 [ 30720 ] {46e0ab07-1829-45c8-b5a9-70e7156f8d18} executeQuery: Code: 42. DB::Exception: Number of arguments for function getMacro doesn't match: passed 3, should be 1: In scope SELECT getMacro(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT getMacro(NULL, NULL, NULL);) 2025.10.23 23:49:25.068163 [ 30720 ] {46e0ab07-1829-45c8-b5a9-70e7156f8d18} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getMacro doesn't match: passed 3, should be 1: In scope SELECT getMacro(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:25.163222 [ 30720 ] {e2f04ac5-92cb-484a-b4f5-30c74b0591f5} executeQuery: Code: 42. DB::Exception: Number of arguments for function getOSKernelVersion doesn't match: passed 3, should be 0: In scope SELECT getOSKernelVersion(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT getOSKernelVersion(NULL, NULL, NULL);) 2025.10.23 23:49:25.167681 [ 30720 ] {e2f04ac5-92cb-484a-b4f5-30c74b0591f5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getOSKernelVersion doesn't match: passed 3, should be 0: In scope SELECT getOSKernelVersion(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:25.235570 [ 30720 ] {6c6af3d9-2955-4fce-a231-befd39839a53} executeQuery: Code: 42. DB::Exception: Number of arguments for function getServerPort doesn't match: passed 3, should be 1: In scope SELECT getServerPort(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT getServerPort(NULL, NULL, NULL);) 2025.10.23 23:49:25.240241 [ 30720 ] {6c6af3d9-2955-4fce-a231-befd39839a53} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getServerPort doesn't match: passed 3, should be 1: In scope SELECT getServerPort(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:25.275376 [ 30720 ] {730fb4a5-ceb3-47fc-9d1a-e30a050c0f91} executeQuery: Code: 42. DB::Exception: Number of arguments for function getSetting doesn't match: passed 3, should be 1: In scope SELECT getSetting(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT getSetting(NULL, NULL, NULL);) 2025.10.23 23:49:25.280113 [ 30720 ] {730fb4a5-ceb3-47fc-9d1a-e30a050c0f91} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getSetting doesn't match: passed 3, should be 1: In scope SELECT getSetting(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:25.374840 [ 3190 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:25.375220 [ 3210 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:25.383050 [ 30720 ] {a614da94-f336-4a01-a755-d84ca5f1fbc7} executeQuery: Code: 42. DB::Exception: Number of arguments for function getSizeOfEnumType doesn't match: passed 3, should be 1: In scope SELECT getSizeOfEnumType(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT getSizeOfEnumType(NULL, NULL, NULL);) 2025.10.23 23:49:25.387031 [ 30720 ] {a614da94-f336-4a01-a755-d84ca5f1fbc7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getSizeOfEnumType doesn't match: passed 3, should be 1: In scope SELECT getSizeOfEnumType(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:25.421622 [ 30720 ] {cbdad514-e6a3-4357-aa13-e7a7225b0b31} executeQuery: Code: 42. DB::Exception: Number of arguments for function getSubcolumn doesn't match: passed 3, should be 2: In scope SELECT getSubcolumn(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT getSubcolumn(NULL, NULL, NULL);) 2025.10.23 23:49:25.425366 [ 30720 ] {cbdad514-e6a3-4357-aa13-e7a7225b0b31} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getSubcolumn doesn't match: passed 3, should be 2: In scope SELECT getSubcolumn(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:25.455058 [ 3199 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:25.533005 [ 30720 ] {d64ea5a2-c60a-4002-950f-0e69b932f79f} executeQuery: Code: 42. DB::Exception: Number of arguments for function getTypeSerializationStreams doesn't match: passed 3, should be 1: In scope SELECT getTypeSerializationStreams(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT getTypeSerializationStreams(NULL, NULL, NULL);) 2025.10.23 23:49:25.535853 [ 30720 ] {d64ea5a2-c60a-4002-950f-0e69b932f79f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getTypeSerializationStreams doesn't match: passed 3, should be 1: In scope SELECT getTypeSerializationStreams(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:25.563506 [ 30720 ] {d6cd76b9-6ccb-43ea-a40e-3921b6752915} executeQuery: Code: 42. DB::Exception: Function 'globalIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT globalIn(NULL, NULL, NULL);) 2025.10.23 23:49:25.566945 [ 30720 ] {d6cd76b9-6ccb-43ea-a40e-3921b6752915} TCPHandler: Code: 42. DB::Exception: Function 'globalIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:25.580391 [ 3202 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:25.595750 [ 29264 ] {daa56e4b-3c06-4106-8311-ca8a5a64603e} executeQuery: Code: 57. DB::Exception: Table test_1.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:49220) (comment: 02497_storage_join_right_assert.sql) (in query: CREATE TABLE t1 (key UInt64, a 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:49:25.599374 [ 30720 ] {a9f77a2c-f108-4fff-ace3-bf152ef65c0a} executeQuery: Code: 42. DB::Exception: Function 'globalInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT globalInIgnoreSet(NULL, NULL, NULL);) 2025.10.23 23:49:25.600003 [ 29264 ] {daa56e4b-3c06-4106-8311-ca8a5a64603e} TCPHandler: Code: 57. DB::Exception: Table test_1.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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:49:25.603482 [ 30720 ] {a9f77a2c-f108-4fff-ace3-bf152ef65c0a} TCPHandler: Code: 42. DB::Exception: Function 'globalInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:25.709741 [ 3191 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:25.737532 [ 30720 ] {c2dca86f-3598-4d7c-96c1-643ccadeb765} executeQuery: Code: 42. DB::Exception: Function 'globalNotIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT globalNotIn(NULL, NULL, NULL);) 2025.10.23 23:49:25.742489 [ 30720 ] {c2dca86f-3598-4d7c-96c1-643ccadeb765} TCPHandler: Code: 42. DB::Exception: Function 'globalNotIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:25.770540 [ 30720 ] {735d9219-af57-414b-9232-a19ea8317d32} executeQuery: Code: 42. DB::Exception: Function 'globalNotInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT globalNotInIgnoreSet(NULL, NULL, NULL);) 2025.10.23 23:49:25.773127 [ 30720 ] {735d9219-af57-414b-9232-a19ea8317d32} TCPHandler: Code: 42. DB::Exception: Function 'globalNotInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:25.845328 [ 30720 ] {132edece-14d7-412f-ac42-ad20025183ad} executeQuery: Code: 42. DB::Exception: Function 'globalNotNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT globalNotNullIn(NULL, NULL, NULL);) 2025.10.23 23:49:25.848072 [ 3186 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:25.848203 [ 30720 ] {132edece-14d7-412f-ac42-ad20025183ad} TCPHandler: Code: 42. DB::Exception: Function 'globalNotNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:25.881199 [ 30720 ] {a1c8549d-0ce8-4959-91a8-d0c8e015f62a} executeQuery: Code: 42. DB::Exception: Function 'globalNotNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT globalNotNullInIgnoreSet(NULL, NULL, NULL);) 2025.10.23 23:49:25.884483 [ 30720 ] {a1c8549d-0ce8-4959-91a8-d0c8e015f62a} TCPHandler: Code: 42. DB::Exception: Function 'globalNotNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:25.916154 [ 30720 ] {b4ced435-7148-4d06-a28e-facd5ab96f8c} executeQuery: Code: 42. DB::Exception: Function 'globalNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT globalNullIn(NULL, NULL, NULL);) 2025.10.23 23:49:25.918706 [ 30720 ] {b4ced435-7148-4d06-a28e-facd5ab96f8c} TCPHandler: Code: 42. DB::Exception: Function 'globalNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:25.946315 [ 30720 ] {9f5e720a-2cff-4ca3-939b-81f3e7e5b5a6} executeQuery: Code: 42. DB::Exception: Function 'globalNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT globalNullInIgnoreSet(NULL, NULL, NULL);) 2025.10.23 23:49:25.949569 [ 30720 ] {9f5e720a-2cff-4ca3-939b-81f3e7e5b5a6} TCPHandler: Code: 42. DB::Exception: Function 'globalNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:25.987948 [ 30720 ] {af010b5e-a082-4729-aa7c-1c8de25ec532} executeQuery: Code: 42. DB::Exception: Number of arguments for function globalVariable doesn't match: passed 3, should be 1: In scope SELECT globalVariable(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT globalVariable(NULL, NULL, NULL);) 2025.10.23 23:49:25.991614 [ 30720 ] {af010b5e-a082-4729-aa7c-1c8de25ec532} TCPHandler: Code: 42. DB::Exception: Number of arguments for function globalVariable doesn't match: passed 3, should be 1: In scope SELECT globalVariable(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:26.027051 [ 30720 ] {09d0205f-2fe6-45b7-b65e-4426ade2a7df} executeQuery: Code: 42. DB::Exception: Number of arguments for function greatCircleAngle doesn't match: passed 3, should be 4: In scope SELECT greatCircleAngle(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT greatCircleAngle(NULL, NULL, NULL);) 2025.10.23 23:49:26.030374 [ 30720 ] {09d0205f-2fe6-45b7-b65e-4426ade2a7df} TCPHandler: Code: 42. DB::Exception: Number of arguments for function greatCircleAngle doesn't match: passed 3, should be 4: In scope SELECT greatCircleAngle(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:26.110912 [ 30720 ] {b5742f4d-7438-45e3-bf96-34ae90e55fc4} executeQuery: Code: 42. DB::Exception: Number of arguments for function greatCircleDistance doesn't match: passed 3, should be 4: In scope SELECT greatCircleDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT greatCircleDistance(NULL, NULL, NULL);) 2025.10.23 23:49:26.113767 [ 30720 ] {b5742f4d-7438-45e3-bf96-34ae90e55fc4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function greatCircleDistance doesn't match: passed 3, should be 4: In scope SELECT greatCircleDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:26.140600 [ 30720 ] {49e4c96e-c85d-49c3-9c48-48ffa51e5ef0} executeQuery: Code: 42. DB::Exception: Number of arguments for function greater doesn't match: passed 3, should be 2: In scope SELECT greater(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT greater(NULL, NULL, NULL);) 2025.10.23 23:49:26.143094 [ 30720 ] {49e4c96e-c85d-49c3-9c48-48ffa51e5ef0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function greater doesn't match: passed 3, should be 2: In scope SELECT greater(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:26.168965 [ 30720 ] {43e1172c-e09b-4c01-a47a-2b5444a55b9c} executeQuery: Code: 42. DB::Exception: Number of arguments for function greaterOrEquals doesn't match: passed 3, should be 2: In scope SELECT greaterOrEquals(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT greaterOrEquals(NULL, NULL, NULL);) 2025.10.23 23:49:26.171443 [ 30720 ] {43e1172c-e09b-4c01-a47a-2b5444a55b9c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function greaterOrEquals doesn't match: passed 3, should be 2: In scope SELECT greaterOrEquals(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:26.375916 [ 3170 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:26.376273 [ 3165 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:26.427541 [ 29264 ] {cbbdd2a9-c59a-4d5e-b331-2ed20dd5ab45} executeQuery: Code: 57. DB::Exception: Table test_1.t0 already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:49222) (comment: 03268_empty_tuple_update.sql) (in query: CREATE TABLE t0 (c0 Tuple(), c1 int) ENGINE = Memory();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:49:26.431347 [ 29264 ] {cbbdd2a9-c59a-4d5e-b331-2ed20dd5ab45} TCPHandler: Code: 57. DB::Exception: Table test_1.t0 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:49:26.456171 [ 3171 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:26.581489 [ 3166 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:26.688911 [ 30720 ] {50b5492d-4363-452b-99aa-8ee3d8460e89} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT groupArrayMovingAvg(NULL, NULL, NULL);) 2025.10.23 23:49:26.695415 [ 30720 ] {50b5492d-4363-452b-99aa-8ee3d8460e89} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) 2025.10.23 23:49:26.710841 [ 3169 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:26.849074 [ 3158 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:27.376860 [ 3146 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:27.376908 [ 3142 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:27.457108 [ 3137 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:27.582402 [ 3128 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:27.711944 [ 3164 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:27.850285 [ 3125 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:28.000549 [ 30720 ] {d99f8fd1-d858-4dd5-bc5f-7e2f53c5adcd} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3CellAreaM2 doesn't match: passed 3, should be 1: In scope SELECT h3CellAreaM2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3CellAreaM2(NULL, NULL, NULL);) 2025.10.23 23:49:28.003246 [ 30720 ] {d99f8fd1-d858-4dd5-bc5f-7e2f53c5adcd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3CellAreaM2 doesn't match: passed 3, should be 1: In scope SELECT h3CellAreaM2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:28.039680 [ 30720 ] {bc91551b-a373-4727-91f0-a2053a1325ca} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3CellAreaRads2 doesn't match: passed 3, should be 1: In scope SELECT h3CellAreaRads2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3CellAreaRads2(NULL, NULL, NULL);) 2025.10.23 23:49:28.042762 [ 30720 ] {bc91551b-a373-4727-91f0-a2053a1325ca} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3CellAreaRads2 doesn't match: passed 3, should be 1: In scope SELECT h3CellAreaRads2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:28.149298 [ 30720 ] {8029c9b3-be27-4189-8fb9-1fbbcb7cbb1f} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3Distance doesn't match: passed 3, should be 2: In scope SELECT h3Distance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3Distance(NULL, NULL, NULL);) 2025.10.23 23:49:28.151820 [ 30720 ] {8029c9b3-be27-4189-8fb9-1fbbcb7cbb1f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3Distance doesn't match: passed 3, should be 2: In scope SELECT h3Distance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:28.180843 [ 30720 ] {22658f2b-7be7-4838-bf55-e30c4ac38b8c} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3EdgeAngle doesn't match: passed 3, should be 1: In scope SELECT h3EdgeAngle(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3EdgeAngle(NULL, NULL, NULL);) 2025.10.23 23:49:28.183634 [ 30720 ] {22658f2b-7be7-4838-bf55-e30c4ac38b8c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3EdgeAngle doesn't match: passed 3, should be 1: In scope SELECT h3EdgeAngle(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:28.211579 [ 30720 ] {3e4851ed-f0ce-4750-b5e3-0c78a752616b} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3EdgeLengthKm doesn't match: passed 3, should be 1: In scope SELECT h3EdgeLengthKm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3EdgeLengthKm(NULL, NULL, NULL);) 2025.10.23 23:49:28.214390 [ 30720 ] {3e4851ed-f0ce-4750-b5e3-0c78a752616b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3EdgeLengthKm doesn't match: passed 3, should be 1: In scope SELECT h3EdgeLengthKm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:28.293454 [ 30720 ] {c2fb6205-8ded-49b2-8f17-e3f07ef0dc70} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3EdgeLengthM doesn't match: passed 3, should be 1: In scope SELECT h3EdgeLengthM(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3EdgeLengthM(NULL, NULL, NULL);) 2025.10.23 23:49:28.297152 [ 30720 ] {c2fb6205-8ded-49b2-8f17-e3f07ef0dc70} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3EdgeLengthM doesn't match: passed 3, should be 1: In scope SELECT h3EdgeLengthM(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:28.332500 [ 30720 ] {4c55151a-6f00-45f3-b36b-4273e8a3883f} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthKm doesn't match: passed 3, should be 1: In scope SELECT h3ExactEdgeLengthKm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3ExactEdgeLengthKm(NULL, NULL, NULL);) 2025.10.23 23:49:28.335291 [ 30720 ] {4c55151a-6f00-45f3-b36b-4273e8a3883f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthKm doesn't match: passed 3, should be 1: In scope SELECT h3ExactEdgeLengthKm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:28.365639 [ 30720 ] {0c3927be-c356-41cb-a4dd-20e6d7350ad3} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthM doesn't match: passed 3, should be 1: In scope SELECT h3ExactEdgeLengthM(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3ExactEdgeLengthM(NULL, NULL, NULL);) 2025.10.23 23:49:28.368110 [ 30720 ] {0c3927be-c356-41cb-a4dd-20e6d7350ad3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthM doesn't match: passed 3, should be 1: In scope SELECT h3ExactEdgeLengthM(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:28.377598 [ 3127 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:28.377611 [ 3120 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:28.400102 [ 30720 ] {a2a9024e-e18e-4855-9299-ccf47757138b} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthRads doesn't match: passed 3, should be 1: In scope SELECT h3ExactEdgeLengthRads(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3ExactEdgeLengthRads(NULL, NULL, NULL);) 2025.10.23 23:49:28.402445 [ 30720 ] {a2a9024e-e18e-4855-9299-ccf47757138b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthRads doesn't match: passed 3, should be 1: In scope SELECT h3ExactEdgeLengthRads(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:28.458081 [ 3117 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:28.481126 [ 29264 ] {6dec450a-cf70-4111-ad47-63e1f5f4b2ea} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=748). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:49238) (comment: 01707_join_use_nulls.sql) (in query: SELECT X.dummy+1 FROM system.one X RIGHT JOIN system.one Y ON X.dummy = Y.dummy SETTINGS join_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:49:28.485188 [ 29264 ] {6dec450a-cf70-4111-ad47-63e1f5f4b2ea} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=748). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:49:28.524046 [ 30720 ] {ba0d2635-3b7d-4e2a-a4ee-c6824397a6d2} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetBaseCell doesn't match: passed 3, should be 1: In scope SELECT h3GetBaseCell(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3GetBaseCell(NULL, NULL, NULL);) 2025.10.23 23:49:28.526521 [ 30720 ] {ba0d2635-3b7d-4e2a-a4ee-c6824397a6d2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetBaseCell doesn't match: passed 3, should be 1: In scope SELECT h3GetBaseCell(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:28.561407 [ 30720 ] {09ce9ec0-4ecb-4b49-8a5f-5d4802a4750e} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetDestinationIndexFromUnidirectionalEdge doesn't match: passed 3, should be 1: In scope SELECT h3GetDestinationIndexFromUnidirectionalEdge(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3GetDestinationIndexFromUnidirectionalEdge(NULL, NULL, NULL);) 2025.10.23 23:49:28.564067 [ 30720 ] {09ce9ec0-4ecb-4b49-8a5f-5d4802a4750e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetDestinationIndexFromUnidirectionalEdge doesn't match: passed 3, should be 1: In scope SELECT h3GetDestinationIndexFromUnidirectionalEdge(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:28.565402 [ 4841 ] {57a39282-a92e-4a1f-90e4-24060dd55240} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:39672) (comment: 01707_join_use_nulls.sql) (in query: DROP DATABASE IF EXISTS test_8gq69143 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:49:28.567986 [ 4841 ] {57a39282-a92e-4a1f-90e4-24060dd55240} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:28.583326 [ 3122 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:28.583910 [ 29264 ] {cf1cf0c1-4c9c-4382-8107-93e8dbfc1cc0} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:39678) (comment: 01707_join_use_nulls.sql) (in query: DROP DATABASE IF EXISTS test_8gq69143 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000003494763c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 13. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 14. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 21. ? @ 0x00007f100c857ac3 22. ? @ 0x00007f100c8e9850 2025.10.23 23:49:28.586734 [ 29264 ] {cf1cf0c1-4c9c-4382-8107-93e8dbfc1cc0} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000003494763c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 13. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 14. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 21. ? @ 0x00007f100c857ac3 22. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:28.595311 [ 30720 ] {0e97df46-65f7-47e8-bbe7-4ecbef7a371c} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetFaces doesn't match: passed 3, should be 1: In scope SELECT h3GetFaces(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3GetFaces(NULL, NULL, NULL);) 2025.10.23 23:49:28.597734 [ 30720 ] {0e97df46-65f7-47e8-bbe7-4ecbef7a371c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetFaces doesn't match: passed 3, should be 1: In scope SELECT h3GetFaces(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:28.630210 [ 30720 ] {4f836825-cb8c-4f35-97cd-d55ac124ff97} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetIndexesFromUnidirectionalEdge doesn't match: passed 3, should be 1: In scope SELECT h3GetIndexesFromUnidirectionalEdge(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3GetIndexesFromUnidirectionalEdge(NULL, NULL, NULL);) 2025.10.23 23:49:28.709893 [ 30720 ] {4f836825-cb8c-4f35-97cd-d55ac124ff97} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetIndexesFromUnidirectionalEdge doesn't match: passed 3, should be 1: In scope SELECT h3GetIndexesFromUnidirectionalEdge(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:28.712742 [ 3099 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:28.742228 [ 30720 ] {357358dd-2ee4-4aef-b363-8c37c832c0aa} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetOriginIndexFromUnidirectionalEdge doesn't match: passed 3, should be 1: In scope SELECT h3GetOriginIndexFromUnidirectionalEdge(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3GetOriginIndexFromUnidirectionalEdge(NULL, NULL, NULL);) 2025.10.23 23:49:28.744732 [ 30720 ] {357358dd-2ee4-4aef-b363-8c37c832c0aa} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetOriginIndexFromUnidirectionalEdge doesn't match: passed 3, should be 1: In scope SELECT h3GetOriginIndexFromUnidirectionalEdge(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:28.776192 [ 30720 ] {9838d9ec-30fb-4f99-807e-49c6092f554b} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetPentagonIndexes doesn't match: passed 3, should be 1: In scope SELECT h3GetPentagonIndexes(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3GetPentagonIndexes(NULL, NULL, NULL);) 2025.10.23 23:49:28.778602 [ 30720 ] {9838d9ec-30fb-4f99-807e-49c6092f554b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetPentagonIndexes doesn't match: passed 3, should be 1: In scope SELECT h3GetPentagonIndexes(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:28.804338 [ 30720 ] {aef56fdf-92df-48aa-840f-0539f0edebad} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetRes0Indexes doesn't match: passed 3, should be 0: In scope SELECT h3GetRes0Indexes(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3GetRes0Indexes(NULL, NULL, NULL);) 2025.10.23 23:49:28.806721 [ 30720 ] {aef56fdf-92df-48aa-840f-0539f0edebad} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetRes0Indexes doesn't match: passed 3, should be 0: In scope SELECT h3GetRes0Indexes(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:28.851319 [ 3100 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:29.020207 [ 30720 ] {9116257d-c1a7-4b7a-bb74-daaef057bb40} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetResolution doesn't match: passed 3, should be 1: In scope SELECT h3GetResolution(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3GetResolution(NULL, NULL, NULL);) 2025.10.23 23:49:29.024057 [ 30720 ] {9116257d-c1a7-4b7a-bb74-daaef057bb40} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetResolution doesn't match: passed 3, should be 1: In scope SELECT h3GetResolution(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:29.139240 [ 30720 ] {706ebc68-c7c1-4649-bd89-8743b89dbcee} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdge doesn't match: passed 3, should be 2: In scope SELECT h3GetUnidirectionalEdge(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3GetUnidirectionalEdge(NULL, NULL, NULL);) 2025.10.23 23:49:29.142099 [ 30720 ] {706ebc68-c7c1-4649-bd89-8743b89dbcee} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdge doesn't match: passed 3, should be 2: In scope SELECT h3GetUnidirectionalEdge(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:29.166805 [ 30720 ] {6834fed0-0c31-4aa7-8ea5-03379d1fc52f} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdgeBoundary doesn't match: passed 3, should be 1: In scope SELECT h3GetUnidirectionalEdgeBoundary(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3GetUnidirectionalEdgeBoundary(NULL, NULL, NULL);) 2025.10.23 23:49:29.169325 [ 30720 ] {6834fed0-0c31-4aa7-8ea5-03379d1fc52f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdgeBoundary doesn't match: passed 3, should be 1: In scope SELECT h3GetUnidirectionalEdgeBoundary(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:29.194686 [ 30720 ] {fca9954a-e28e-4891-a366-317b3496ecc3} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdgesFromHexagon doesn't match: passed 3, should be 1: In scope SELECT h3GetUnidirectionalEdgesFromHexagon(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3GetUnidirectionalEdgesFromHexagon(NULL, NULL, NULL);) 2025.10.23 23:49:29.197434 [ 30720 ] {fca9954a-e28e-4891-a366-317b3496ecc3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdgesFromHexagon doesn't match: passed 3, should be 1: In scope SELECT h3GetUnidirectionalEdgesFromHexagon(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:29.223118 [ 30720 ] {f087e8bd-c249-45c8-95cd-9b90383dd99c} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3HexAreaKm2 doesn't match: passed 3, should be 1: In scope SELECT h3HexAreaKm2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3HexAreaKm2(NULL, NULL, NULL);) 2025.10.23 23:49:29.226170 [ 30720 ] {f087e8bd-c249-45c8-95cd-9b90383dd99c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3HexAreaKm2 doesn't match: passed 3, should be 1: In scope SELECT h3HexAreaKm2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:29.272398 [ 30720 ] {3442d862-dd00-43ad-b067-21ec417329d7} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3HexAreaM2 doesn't match: passed 3, should be 1: In scope SELECT h3HexAreaM2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3HexAreaM2(NULL, NULL, NULL);) 2025.10.23 23:49:29.275017 [ 30720 ] {3442d862-dd00-43ad-b067-21ec417329d7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3HexAreaM2 doesn't match: passed 3, should be 1: In scope SELECT h3HexAreaM2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:29.300830 [ 30720 ] {9912635b-83dc-48df-867e-4463695bd4d5} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3HexRing doesn't match: passed 3, should be 2: In scope SELECT h3HexRing(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3HexRing(NULL, NULL, NULL);) 2025.10.23 23:49:29.303751 [ 30720 ] {9912635b-83dc-48df-867e-4463695bd4d5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3HexRing doesn't match: passed 3, should be 2: In scope SELECT h3HexRing(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:29.329051 [ 30720 ] {5052e284-9e98-4c92-b7bd-6b82a39b89c5} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3IndexesAreNeighbors doesn't match: passed 3, should be 2: In scope SELECT h3IndexesAreNeighbors(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3IndexesAreNeighbors(NULL, NULL, NULL);) 2025.10.23 23:49:29.331519 [ 30720 ] {5052e284-9e98-4c92-b7bd-6b82a39b89c5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3IndexesAreNeighbors doesn't match: passed 3, should be 2: In scope SELECT h3IndexesAreNeighbors(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:29.356458 [ 30720 ] {25c24a3f-1a40-43d4-95fd-bc8f2aeb6014} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3IsPentagon doesn't match: passed 3, should be 1: In scope SELECT h3IsPentagon(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3IsPentagon(NULL, NULL, NULL);) 2025.10.23 23:49:29.358863 [ 30720 ] {25c24a3f-1a40-43d4-95fd-bc8f2aeb6014} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3IsPentagon doesn't match: passed 3, should be 1: In scope SELECT h3IsPentagon(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:29.378845 [ 3059 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:29.379606 [ 3059 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:29.383017 [ 30720 ] {0e49148a-38a2-4a22-ae6d-a30e6d7f7806} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3IsResClassIII doesn't match: passed 3, should be 1: In scope SELECT h3IsResClassIII(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3IsResClassIII(NULL, NULL, NULL);) 2025.10.23 23:49:29.385595 [ 30720 ] {0e49148a-38a2-4a22-ae6d-a30e6d7f7806} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3IsResClassIII doesn't match: passed 3, should be 1: In scope SELECT h3IsResClassIII(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:29.409332 [ 30720 ] {169855d5-f769-47bc-b88c-7b66afd75ed6} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3IsValid doesn't match: passed 3, should be 1: In scope SELECT h3IsValid(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3IsValid(NULL, NULL, NULL);) 2025.10.23 23:49:29.411597 [ 30720 ] {169855d5-f769-47bc-b88c-7b66afd75ed6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3IsValid doesn't match: passed 3, should be 1: In scope SELECT h3IsValid(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:29.458994 [ 3066 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:29.463607 [ 30720 ] {a6bf79d0-fd8f-4c5b-9e95-4c6df03e35a7} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3Line doesn't match: passed 3, should be 2: In scope SELECT h3Line(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3Line(NULL, NULL, NULL);) 2025.10.23 23:49:29.466239 [ 30720 ] {a6bf79d0-fd8f-4c5b-9e95-4c6df03e35a7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3Line doesn't match: passed 3, should be 2: In scope SELECT h3Line(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:29.492065 [ 30720 ] {02e762f2-b79d-410a-95f3-82f624c979dd} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3NumHexagons doesn't match: passed 3, should be 1: In scope SELECT h3NumHexagons(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3NumHexagons(NULL, NULL, NULL);) 2025.10.23 23:49:29.584331 [ 3427 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:29.601065 [ 30720 ] {02e762f2-b79d-410a-95f3-82f624c979dd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3NumHexagons doesn't match: passed 3, should be 1: In scope SELECT h3NumHexagons(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:29.698876 [ 30720 ] {920f16e5-3134-467a-83b8-7e64fd0225e4} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3PointDistKm doesn't match: passed 3, should be 4: In scope SELECT h3PointDistKm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3PointDistKm(NULL, NULL, NULL);) 2025.10.23 23:49:29.703140 [ 30720 ] {920f16e5-3134-467a-83b8-7e64fd0225e4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3PointDistKm doesn't match: passed 3, should be 4: In scope SELECT h3PointDistKm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:29.713747 [ 3057 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:29.821483 [ 30720 ] {3934bc85-3b28-42bf-a865-c88f5932356b} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3PointDistM doesn't match: passed 3, should be 4: In scope SELECT h3PointDistM(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3PointDistM(NULL, NULL, NULL);) 2025.10.23 23:49:29.825385 [ 30720 ] {3934bc85-3b28-42bf-a865-c88f5932356b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3PointDistM doesn't match: passed 3, should be 4: In scope SELECT h3PointDistM(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:29.852571 [ 3345 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:29.950727 [ 30720 ] {71496baa-1eab-4378-8aec-a454e78b100e} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3PointDistRads doesn't match: passed 3, should be 4: In scope SELECT h3PointDistRads(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3PointDistRads(NULL, NULL, NULL);) 2025.10.23 23:49:29.954565 [ 30720 ] {71496baa-1eab-4378-8aec-a454e78b100e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3PointDistRads doesn't match: passed 3, should be 4: In scope SELECT h3PointDistRads(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:29.993408 [ 30720 ] {05cc00f2-9bd5-4663-a476-d412ffb805da} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToCenterChild doesn't match: passed 3, should be 2: In scope SELECT h3ToCenterChild(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3ToCenterChild(NULL, NULL, NULL);) 2025.10.23 23:49:30.076185 [ 30720 ] {05cc00f2-9bd5-4663-a476-d412ffb805da} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToCenterChild doesn't match: passed 3, should be 2: In scope SELECT h3ToCenterChild(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:30.116023 [ 30720 ] {c3f52e88-3892-4b3d-aaff-08844b162ba5} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToChildren doesn't match: passed 3, should be 2: In scope SELECT h3ToChildren(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3ToChildren(NULL, NULL, NULL);) 2025.10.23 23:49:30.119546 [ 30720 ] {c3f52e88-3892-4b3d-aaff-08844b162ba5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToChildren doesn't match: passed 3, should be 2: In scope SELECT h3ToChildren(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:30.285173 [ 30720 ] {99e94351-5573-4461-8bef-fdea110d28cc} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToGeo doesn't match: passed 3, should be 1: In scope SELECT h3ToGeo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3ToGeo(NULL, NULL, NULL);) 2025.10.23 23:49:30.289244 [ 30720 ] {99e94351-5573-4461-8bef-fdea110d28cc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToGeo doesn't match: passed 3, should be 1: In scope SELECT h3ToGeo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:30.351121 [ 30720 ] {c710d04f-555d-4e32-8d38-3a2b207b287c} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToGeoBoundary doesn't match: passed 3, should be 1: In scope SELECT h3ToGeoBoundary(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3ToGeoBoundary(NULL, NULL, NULL);) 2025.10.23 23:49:30.355210 [ 30720 ] {c710d04f-555d-4e32-8d38-3a2b207b287c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToGeoBoundary doesn't match: passed 3, should be 1: In scope SELECT h3ToGeoBoundary(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:30.380445 [ 3203 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:30.380566 [ 3168 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:30.388711 [ 30720 ] {60122ea9-6a05-466c-8354-dcd903af6d0c} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToParent doesn't match: passed 3, should be 2: In scope SELECT h3ToParent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3ToParent(NULL, NULL, NULL);) 2025.10.23 23:49:30.391139 [ 30720 ] {60122ea9-6a05-466c-8354-dcd903af6d0c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToParent doesn't match: passed 3, should be 2: In scope SELECT h3ToParent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:30.460154 [ 3135 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:30.506298 [ 30720 ] {874cc470-70e6-4da5-b388-5f32e87695c1} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToString doesn't match: passed 3, should be 1: In scope SELECT h3ToString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3ToString(NULL, NULL, NULL);) 2025.10.23 23:49:30.508972 [ 30720 ] {874cc470-70e6-4da5-b388-5f32e87695c1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToString doesn't match: passed 3, should be 1: In scope SELECT h3ToString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:30.557889 [ 30720 ] {f17f2a7d-6646-406a-9fe6-bf48e8abaa72} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3UnidirectionalEdgeIsValid doesn't match: passed 3, should be 1: In scope SELECT h3UnidirectionalEdgeIsValid(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3UnidirectionalEdgeIsValid(NULL, NULL, NULL);) 2025.10.23 23:49:30.585431 [ 3174 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:30.650709 [ 30720 ] {f17f2a7d-6646-406a-9fe6-bf48e8abaa72} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3UnidirectionalEdgeIsValid doesn't match: passed 3, should be 1: In scope SELECT h3UnidirectionalEdgeIsValid(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:30.677806 [ 30720 ] {c28ea1ab-a8ba-4682-93f7-1a90081972c7} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3kRing doesn't match: passed 3, should be 2: In scope SELECT h3kRing(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3kRing(NULL, NULL, NULL);) 2025.10.23 23:49:30.680567 [ 30720 ] {c28ea1ab-a8ba-4682-93f7-1a90081972c7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3kRing doesn't match: passed 3, should be 2: In scope SELECT h3kRing(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:30.714626 [ 3562 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:30.747890 [ 30720 ] {914db26c-699d-4cf9-acdb-1df68ee76d7f} executeQuery: Code: 42. DB::Exception: Number of arguments for function has doesn't match: passed 3, should be 2: In scope SELECT has(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT has(NULL, NULL, NULL);) 2025.10.23 23:49:30.750414 [ 30720 ] {914db26c-699d-4cf9-acdb-1df68ee76d7f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function has doesn't match: passed 3, should be 2: In scope SELECT has(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:30.776347 [ 30720 ] {e81167c5-f283-4166-a8c8-94448f81e958} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasAll doesn't match: passed 3, should be 2: In scope SELECT hasAll(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT hasAll(NULL, NULL, NULL);) 2025.10.23 23:49:30.778843 [ 30720 ] {e81167c5-f283-4166-a8c8-94448f81e958} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasAll doesn't match: passed 3, should be 2: In scope SELECT hasAll(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:30.853819 [ 3564 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:30.874207 [ 30720 ] {d2a3dfec-2f78-49a3-b102-4f9cd3cd9cfb} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasAny doesn't match: passed 3, should be 2: In scope SELECT hasAny(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT hasAny(NULL, NULL, NULL);) 2025.10.23 23:49:30.876972 [ 30720 ] {d2a3dfec-2f78-49a3-b102-4f9cd3cd9cfb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasAny doesn't match: passed 3, should be 2: In scope SELECT hasAny(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:30.944728 [ 30720 ] {01ba17b4-cd64-4a53-b011-2bc6d83b7a31} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasSubsequence doesn't match: passed 3, should be 2: In scope SELECT hasSubsequence(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT hasSubsequence(NULL, NULL, NULL);) 2025.10.23 23:49:30.947843 [ 30720 ] {01ba17b4-cd64-4a53-b011-2bc6d83b7a31} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasSubsequence doesn't match: passed 3, should be 2: In scope SELECT hasSubsequence(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:30.978348 [ 30720 ] {3fe6a78d-949a-4694-8399-dec4d7f0bf6d} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT hasSubsequenceCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT hasSubsequenceCaseInsensitive(NULL, NULL, NULL);) 2025.10.23 23:49:30.981589 [ 30720 ] {3fe6a78d-949a-4694-8399-dec4d7f0bf6d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT hasSubsequenceCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:31.018618 [ 30720 ] {7add27f6-2439-4ea1-b332-f0671ff90cfc} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT hasSubsequenceCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT hasSubsequenceCaseInsensitiveUTF8(NULL, NULL, NULL);) 2025.10.23 23:49:31.022226 [ 30720 ] {7add27f6-2439-4ea1-b332-f0671ff90cfc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT hasSubsequenceCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:31.060157 [ 30720 ] {732a45b8-08c0-4247-837b-5de5d39c4bb4} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceUTF8 doesn't match: passed 3, should be 2: In scope SELECT hasSubsequenceUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT hasSubsequenceUTF8(NULL, NULL, NULL);) 2025.10.23 23:49:31.063406 [ 30720 ] {732a45b8-08c0-4247-837b-5de5d39c4bb4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceUTF8 doesn't match: passed 3, should be 2: In scope SELECT hasSubsequenceUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:31.150686 [ 30720 ] {645a1ccf-b782-4d18-96d6-4c44fba97c41} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasSubstr doesn't match: passed 3, should be 2: In scope SELECT hasSubstr(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT hasSubstr(NULL, NULL, NULL);) 2025.10.23 23:49:31.153480 [ 30720 ] {645a1ccf-b782-4d18-96d6-4c44fba97c41} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasSubstr doesn't match: passed 3, should be 2: In scope SELECT hasSubstr(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:31.178135 [ 30720 ] {dc33257e-4456-41f5-8de2-63811dfe6835} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasThreadFuzzer doesn't match: passed 3, should be 0: In scope SELECT hasThreadFuzzer(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT hasThreadFuzzer(NULL, NULL, NULL);) 2025.10.23 23:49:31.251456 [ 30720 ] {dc33257e-4456-41f5-8de2-63811dfe6835} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasThreadFuzzer doesn't match: passed 3, should be 0: In scope SELECT hasThreadFuzzer(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:31.276176 [ 30720 ] {7e3f4c69-a7e8-46c5-8fb9-10d58592a0a1} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasToken doesn't match: passed 3, should be 2: In scope SELECT hasToken(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT hasToken(NULL, NULL, NULL);) 2025.10.23 23:49:31.278600 [ 30720 ] {7e3f4c69-a7e8-46c5-8fb9-10d58592a0a1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasToken doesn't match: passed 3, should be 2: In scope SELECT hasToken(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:31.302868 [ 30720 ] {3157392e-9101-4894-97e4-fb39aa782527} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasTokenCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT hasTokenCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT hasTokenCaseInsensitive(NULL, NULL, NULL);) 2025.10.23 23:49:31.305424 [ 30720 ] {3157392e-9101-4894-97e4-fb39aa782527} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasTokenCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT hasTokenCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:31.330003 [ 30720 ] {a2407eb6-4e56-44ec-b7bc-86efd9405dcd} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasTokenCaseInsensitiveOrNull doesn't match: passed 3, should be 2: In scope SELECT hasTokenCaseInsensitiveOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT hasTokenCaseInsensitiveOrNull(NULL, NULL, NULL);) 2025.10.23 23:49:31.332596 [ 30720 ] {a2407eb6-4e56-44ec-b7bc-86efd9405dcd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasTokenCaseInsensitiveOrNull doesn't match: passed 3, should be 2: In scope SELECT hasTokenCaseInsensitiveOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:31.381662 [ 3555 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:31.381825 [ 3565 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:31.451250 [ 30720 ] {e2239aed-cc6c-4829-ae4b-b1a2ea43b099} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasTokenOrNull doesn't match: passed 3, should be 2: In scope SELECT hasTokenOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT hasTokenOrNull(NULL, NULL, NULL);) 2025.10.23 23:49:31.455441 [ 30720 ] {e2239aed-cc6c-4829-ae4b-b1a2ea43b099} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasTokenOrNull doesn't match: passed 3, should be 2: In scope SELECT hasTokenOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:31.461316 [ 3074 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:31.499031 [ 30720 ] {acc653d4-1a41-4da4-b427-0382bbb74d18} executeQuery: Code: 42. DB::Exception: Number of arguments for function hex doesn't match: passed 3, should be 1: In scope SELECT hex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT hex(NULL, NULL, NULL);) 2025.10.23 23:49:31.503058 [ 30720 ] {acc653d4-1a41-4da4-b427-0382bbb74d18} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hex doesn't match: passed 3, should be 1: In scope SELECT hex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:31.545822 [ 30720 ] {90f09eb6-cc51-4677-8401-0572b897febd} executeQuery: Code: 42. DB::Exception: Number of arguments for function hilbertDecode doesn't match: passed 3, should be 2: In scope SELECT hilbertDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT hilbertDecode(NULL, NULL, NULL);) 2025.10.23 23:49:31.549638 [ 30720 ] {90f09eb6-cc51-4677-8401-0572b897febd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hilbertDecode doesn't match: passed 3, should be 2: In scope SELECT hilbertDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:31.586566 [ 3558 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:31.715549 [ 3554 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:31.869375 [ 3549 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:32.168151 [ 30720 ] {3e8334e3-7184-405b-a3dd-33cfa69fee14} executeQuery: Code: 42. DB::Exception: Number of arguments for function hostName doesn't match: passed 3, should be 0: In scope SELECT hostName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT hostName(NULL, NULL, NULL);) 2025.10.23 23:49:32.170574 [ 30720 ] {3e8334e3-7184-405b-a3dd-33cfa69fee14} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hostName doesn't match: passed 3, should be 0: In scope SELECT hostName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:32.201792 [ 30720 ] {17690692-f13d-4a5f-9095-64a84ae46bd8} executeQuery: Code: 42. DB::Exception: Number of arguments for function hostName doesn't match: passed 3, should be 0: In scope SELECT hostname(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT hostname(NULL, NULL, NULL);) 2025.10.23 23:49:32.204337 [ 30720 ] {17690692-f13d-4a5f-9095-64a84ae46bd8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hostName doesn't match: passed 3, should be 0: In scope SELECT hostname(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:32.228355 [ 30720 ] {381ab171-2e7c-4908-ae0c-61799405edcc} executeQuery: Code: 42. DB::Exception: Number of arguments for function hypot doesn't match: passed 3, should be 2: In scope SELECT hypot(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT hypot(NULL, NULL, NULL);) 2025.10.23 23:49:32.230609 [ 30720 ] {381ab171-2e7c-4908-ae0c-61799405edcc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hypot doesn't match: passed 3, should be 2: In scope SELECT hypot(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:32.347574 [ 30720 ] {a95e8301-8830-4cac-9494-6cf39bc282b0} executeQuery: Code: 42. DB::Exception: Number of arguments for function identity doesn't match: passed 3, should be 1: In scope SELECT identity(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT identity(NULL, NULL, NULL);) 2025.10.23 23:49:32.350212 [ 30720 ] {a95e8301-8830-4cac-9494-6cf39bc282b0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function identity doesn't match: passed 3, should be 1: In scope SELECT identity(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:32.382808 [ 3539 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:32.383168 [ 3524 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:32.384153 [ 30720 ] {b7df85e0-4446-42a3-bd09-0e2e29e224be} executeQuery: Code: 42. DB::Exception: Number of arguments for function idnaDecode doesn't match: passed 3, should be 1: In scope SELECT idnaDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT idnaDecode(NULL, NULL, NULL);) 2025.10.23 23:49:32.386409 [ 30720 ] {b7df85e0-4446-42a3-bd09-0e2e29e224be} TCPHandler: Code: 42. DB::Exception: Number of arguments for function idnaDecode doesn't match: passed 3, should be 1: In scope SELECT idnaDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:32.462614 [ 3508 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:32.496437 [ 30720 ] {f96f2e03-f1ac-49a1-93cd-417a6f67645a} executeQuery: Code: 42. DB::Exception: Number of arguments for function idnaEncode doesn't match: passed 3, should be 1: In scope SELECT idnaEncode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT idnaEncode(NULL, NULL, NULL);) 2025.10.23 23:49:32.499022 [ 30720 ] {f96f2e03-f1ac-49a1-93cd-417a6f67645a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function idnaEncode doesn't match: passed 3, should be 1: In scope SELECT idnaEncode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:32.577763 [ 30720 ] {b68a554e-0ab6-4217-a56c-9bec51cc5e28} executeQuery: Code: 42. DB::Exception: Number of arguments for function ifNotFinite doesn't match: passed 3, should be 2: In scope SELECT ifNotFinite(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT ifNotFinite(NULL, NULL, NULL);) 2025.10.23 23:49:32.580341 [ 30720 ] {b68a554e-0ab6-4217-a56c-9bec51cc5e28} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ifNotFinite doesn't match: passed 3, should be 2: In scope SELECT ifNotFinite(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:32.588069 [ 3505 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:32.611073 [ 30720 ] {991a127d-fa19-4c47-bf4d-2c598f84e2d1} executeQuery: Code: 42. DB::Exception: Number of arguments for function ifNull doesn't match: passed 3, should be 2: In scope SELECT ifNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT ifNull(NULL, NULL, NULL);) 2025.10.23 23:49:32.654220 [ 30720 ] {991a127d-fa19-4c47-bf4d-2c598f84e2d1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ifNull doesn't match: passed 3, should be 2: In scope SELECT ifNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:32.716847 [ 3522 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:32.739573 [ 30720 ] {3f9bc492-e911-490f-9f1f-8d90bfecc36e} executeQuery: Code: 42. DB::Exception: Number of arguments for function ilike doesn't match: passed 3, should be 2: In scope SELECT ilike(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT ilike(NULL, NULL, NULL);) 2025.10.23 23:49:32.742152 [ 30720 ] {3f9bc492-e911-490f-9f1f-8d90bfecc36e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ilike doesn't match: passed 3, should be 2: In scope SELECT ilike(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:32.769464 [ 30720 ] {c95aadcf-b9ba-4f49-9915-ce45f6dde07b} executeQuery: Code: 42. DB::Exception: Function 'in' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT in(NULL, NULL, NULL);) 2025.10.23 23:49:32.772357 [ 30720 ] {c95aadcf-b9ba-4f49-9915-ce45f6dde07b} TCPHandler: Code: 42. DB::Exception: Function 'in' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:32.796954 [ 30720 ] {cbb1caaa-9c5c-4af7-819c-89171564f6bd} executeQuery: Code: 42. DB::Exception: Function 'inIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT inIgnoreSet(NULL, NULL, NULL);) 2025.10.23 23:49:32.799672 [ 30720 ] {cbb1caaa-9c5c-4af7-819c-89171564f6bd} TCPHandler: Code: 42. DB::Exception: Function 'inIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:32.867029 [ 30720 ] {c991b28b-b680-460a-8bf6-f64becfeadbf} executeQuery: Code: 42. DB::Exception: Number of arguments for function indexOf doesn't match: passed 3, should be 2: In scope SELECT indexOf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT indexOf(NULL, NULL, NULL);) 2025.10.23 23:49:32.869969 [ 30720 ] {c991b28b-b680-460a-8bf6-f64becfeadbf} TCPHandler: Code: 42. DB::Exception: Number of arguments for function indexOf doesn't match: passed 3, should be 2: In scope SELECT indexOf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:32.870560 [ 3495 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:32.894312 [ 30720 ] {d45f00e0-384d-4a23-aac7-35087be0cc5a} executeQuery: Code: 42. DB::Exception: Number of arguments for function initcap doesn't match: passed 3, should be 1: In scope SELECT initcap(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT initcap(NULL, NULL, NULL);) 2025.10.23 23:49:32.897099 [ 30720 ] {d45f00e0-384d-4a23-aac7-35087be0cc5a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initcap doesn't match: passed 3, should be 1: In scope SELECT initcap(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:32.920754 [ 30720 ] {025c55f5-f5f6-41cb-86e4-7f3898d71424} executeQuery: Code: 42. DB::Exception: Number of arguments for function initcapUTF8 doesn't match: passed 3, should be 1: In scope SELECT initcapUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT initcapUTF8(NULL, NULL, NULL);) 2025.10.23 23:49:32.923121 [ 30720 ] {025c55f5-f5f6-41cb-86e4-7f3898d71424} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initcapUTF8 doesn't match: passed 3, should be 1: In scope SELECT initcapUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:32.948155 [ 30720 ] {dc988d8c-169e-4eaf-827d-491322e2580e} executeQuery: Code: 42. DB::Exception: Number of arguments for function initialQueryID doesn't match: passed 3, should be 0: In scope SELECT initialQueryID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT initialQueryID(NULL, NULL, NULL);) 2025.10.23 23:49:32.950743 [ 30720 ] {dc988d8c-169e-4eaf-827d-491322e2580e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initialQueryID doesn't match: passed 3, should be 0: In scope SELECT initialQueryID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:32.981874 [ 30720 ] {4346e266-f50c-45ce-b504-2566e346cfde} executeQuery: Code: 42. DB::Exception: Number of arguments for function initialQueryID doesn't match: passed 3, should be 0: In scope SELECT initial_query_id(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT initial_query_id(NULL, NULL, NULL);) 2025.10.23 23:49:32.984567 [ 30720 ] {4346e266-f50c-45ce-b504-2566e346cfde} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initialQueryID doesn't match: passed 3, should be 0: In scope SELECT initial_query_id(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:33.015603 [ 30720 ] {6b649d99-305c-468c-aa75-e6ac66c07ce2} executeQuery: Code: 43. DB::Exception: First argument for function initializeAggregation must be constant string: name of aggregate function.: In scope SELECT initializeAggregation(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT initializeAggregation(NULL, NULL, NULL);) 2025.10.23 23:49:33.018400 [ 30720 ] {6b649d99-305c-468c-aa75-e6ac66c07ce2} TCPHandler: Code: 43. DB::Exception: First argument for function initializeAggregation must be constant string: name of aggregate function.: In scope SELECT initializeAggregation(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:49:33.104214 [ 30720 ] {45d3bfd3-3a8c-4ecb-a4d7-c9dbdfb8321d} executeQuery: Code: 42. DB::Exception: Number of arguments for function intDiv doesn't match: passed 3, should be 2: In scope SELECT intDiv(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT intDiv(NULL, NULL, NULL);) 2025.10.23 23:49:33.107435 [ 30720 ] {45d3bfd3-3a8c-4ecb-a4d7-c9dbdfb8321d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intDiv doesn't match: passed 3, should be 2: In scope SELECT intDiv(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:33.145929 [ 30720 ] {8b85e835-b611-413b-a26f-6765a641085e} executeQuery: Code: 42. DB::Exception: Number of arguments for function intDivOrZero doesn't match: passed 3, should be 2: In scope SELECT intDivOrZero(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT intDivOrZero(NULL, NULL, NULL);) 2025.10.23 23:49:33.149719 [ 30720 ] {8b85e835-b611-413b-a26f-6765a641085e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intDivOrZero doesn't match: passed 3, should be 2: In scope SELECT intDivOrZero(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:33.239886 [ 30720 ] {ef5922a6-990f-4f49-91d2-a238fbaafb31} executeQuery: Code: 42. DB::Exception: Number of arguments for function intExp10 doesn't match: passed 3, should be 1: In scope SELECT intExp10(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT intExp10(NULL, NULL, NULL);) 2025.10.23 23:49:33.243957 [ 30720 ] {ef5922a6-990f-4f49-91d2-a238fbaafb31} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intExp10 doesn't match: passed 3, should be 1: In scope SELECT intExp10(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:33.283209 [ 30720 ] {975a842d-2a1c-49f4-8d01-5356195fe466} executeQuery: Code: 42. DB::Exception: Number of arguments for function intExp2 doesn't match: passed 3, should be 1: In scope SELECT intExp2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT intExp2(NULL, NULL, NULL);) 2025.10.23 23:49:33.287071 [ 30720 ] {975a842d-2a1c-49f4-8d01-5356195fe466} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intExp2 doesn't match: passed 3, should be 1: In scope SELECT intExp2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:33.326501 [ 30720 ] {cffebecd-0110-46d8-9b92-d2b6a991121e} executeQuery: Code: 42. DB::Exception: Number of arguments for function intHash32 doesn't match: passed 3, should be 1: In scope SELECT intHash32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT intHash32(NULL, NULL, NULL);) 2025.10.23 23:49:33.330608 [ 30720 ] {cffebecd-0110-46d8-9b92-d2b6a991121e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intHash32 doesn't match: passed 3, should be 1: In scope SELECT intHash32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:33.370637 [ 30720 ] {ee1f184b-316f-4ff6-bf43-fcad91367674} executeQuery: Code: 42. DB::Exception: Number of arguments for function intHash64 doesn't match: passed 3, should be 1: In scope SELECT intHash64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT intHash64(NULL, NULL, NULL);) 2025.10.23 23:49:33.376986 [ 30720 ] {ee1f184b-316f-4ff6-bf43-fcad91367674} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intHash64 doesn't match: passed 3, should be 1: In scope SELECT intHash64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:33.384090 [ 3465 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:33.384402 [ 3457 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:33.464138 [ 3454 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:33.589596 [ 3456 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:33.704552 [ 30720 ] {91f651fa-6ac3-4c4f-be89-d960b2473ab3} executeQuery: Code: 42. DB::Exception: Number of arguments for function isConstant doesn't match: passed 3, should be 1: In scope SELECT isConstant(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT isConstant(NULL, NULL, NULL);) 2025.10.23 23:49:33.708708 [ 30720 ] {91f651fa-6ac3-4c4f-be89-d960b2473ab3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isConstant doesn't match: passed 3, should be 1: In scope SELECT isConstant(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:33.718052 [ 3434 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:33.821780 [ 30720 ] {bdde823c-00d4-4f34-8f1a-62dd75f39edf} executeQuery: Code: 42. DB::Exception: Number of arguments for function isDynamicElementInSharedData doesn't match: passed 3, should be 1: In scope SELECT isDynamicElementInSharedData(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT isDynamicElementInSharedData(NULL, NULL, NULL);) 2025.10.23 23:49:33.825022 [ 30720 ] {bdde823c-00d4-4f34-8f1a-62dd75f39edf} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isDynamicElementInSharedData doesn't match: passed 3, should be 1: In scope SELECT isDynamicElementInSharedData(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:33.859456 [ 30720 ] {746fda5d-fcec-441f-b7a6-75b66001c827} executeQuery: Code: 42. DB::Exception: Number of arguments for function isFinite doesn't match: passed 3, should be 1: In scope SELECT isFinite(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT isFinite(NULL, NULL, NULL);) 2025.10.23 23:49:33.862337 [ 30720 ] {746fda5d-fcec-441f-b7a6-75b66001c827} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isFinite doesn't match: passed 3, should be 1: In scope SELECT isFinite(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:33.871617 [ 3441 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:34.023002 [ 30720 ] {a46284b2-405b-4805-ae97-c703ee209136} executeQuery: Code: 42. DB::Exception: Number of arguments for function isIPAddressInRange doesn't match: passed 3, should be 2: In scope SELECT isIPAddressInRange(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT isIPAddressInRange(NULL, NULL, NULL);) 2025.10.23 23:49:34.115855 [ 30720 ] {a46284b2-405b-4805-ae97-c703ee209136} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isIPAddressInRange doesn't match: passed 3, should be 2: In scope SELECT isIPAddressInRange(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:34.155223 [ 30720 ] {270fa821-8933-4776-9e66-12764efc5c39} executeQuery: Code: 42. DB::Exception: Number of arguments for function isIPv4String doesn't match: passed 3, should be 1: In scope SELECT isIPv4String(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT isIPv4String(NULL, NULL, NULL);) 2025.10.23 23:49:34.159113 [ 30720 ] {270fa821-8933-4776-9e66-12764efc5c39} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isIPv4String doesn't match: passed 3, should be 1: In scope SELECT isIPv4String(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:34.290039 [ 30720 ] {0d585763-9618-4585-a449-c73d9287ece3} executeQuery: Code: 42. DB::Exception: Number of arguments for function isIPv6String doesn't match: passed 3, should be 1: In scope SELECT isIPv6String(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT isIPv6String(NULL, NULL, NULL);) 2025.10.23 23:49:34.292702 [ 30720 ] {0d585763-9618-4585-a449-c73d9287ece3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isIPv6String doesn't match: passed 3, should be 1: In scope SELECT isIPv6String(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:34.343232 [ 30720 ] {76d0e428-399b-4127-af83-484c80df977b} executeQuery: Code: 42. DB::Exception: Number of arguments for function isInfinite doesn't match: passed 3, should be 1: In scope SELECT isInfinite(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT isInfinite(NULL, NULL, NULL);) 2025.10.23 23:49:34.345961 [ 30720 ] {76d0e428-399b-4127-af83-484c80df977b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isInfinite doesn't match: passed 3, should be 1: In scope SELECT isInfinite(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:34.378474 [ 30720 ] {e665a8b3-1038-4a6d-b4c0-996900717cbd} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNaN doesn't match: passed 3, should be 1: In scope SELECT isNaN(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT isNaN(NULL, NULL, NULL);) 2025.10.23 23:49:34.385353 [ 3428 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:34.385366 [ 3436 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:34.465448 [ 3422 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:34.467278 [ 30720 ] {e665a8b3-1038-4a6d-b4c0-996900717cbd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNaN doesn't match: passed 3, should be 1: In scope SELECT isNaN(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:34.557705 [ 30720 ] {0a57b76e-179b-4f8e-8cb4-527443e1b1e1} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNotDistinctFrom doesn't match: passed 3, should be 2: In scope SELECT isNotDistinctFrom(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT isNotDistinctFrom(NULL, NULL, NULL);) 2025.10.23 23:49:34.561626 [ 30720 ] {0a57b76e-179b-4f8e-8cb4-527443e1b1e1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNotDistinctFrom doesn't match: passed 3, should be 2: In scope SELECT isNotDistinctFrom(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:34.590808 [ 3415 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:34.593316 [ 30720 ] {47351366-915e-4fed-b2c7-c0c901e2e178} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNotNull doesn't match: passed 3, should be 1: In scope SELECT isNotNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT isNotNull(NULL, NULL, NULL);) 2025.10.23 23:49:34.597001 [ 30720 ] {47351366-915e-4fed-b2c7-c0c901e2e178} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNotNull doesn't match: passed 3, should be 1: In scope SELECT isNotNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:34.682691 [ 30720 ] {b1e01747-dadb-4171-bc65-58b5e04e8d9a} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNull doesn't match: passed 3, should be 1: In scope SELECT isNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT isNull(NULL, NULL, NULL);) 2025.10.23 23:49:34.686687 [ 30720 ] {b1e01747-dadb-4171-bc65-58b5e04e8d9a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNull doesn't match: passed 3, should be 1: In scope SELECT isNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:34.719264 [ 3412 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:34.801626 [ 30720 ] {fdba5c3e-a8f9-4db7-a60a-389692167f40} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNullable doesn't match: passed 3, should be 1: In scope SELECT isNullable(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT isNullable(NULL, NULL, NULL);) 2025.10.23 23:49:34.809761 [ 30720 ] {fdba5c3e-a8f9-4db7-a60a-389692167f40} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNullable doesn't match: passed 3, should be 1: In scope SELECT isNullable(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:34.843450 [ 30720 ] {447430c3-6d5d-4827-9812-1a55ee8d8b96} executeQuery: Code: 42. DB::Exception: Function isValidJSON needs exactly one argument: In scope SELECT isValidJSON(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT isValidJSON(NULL, NULL, NULL);) 2025.10.23 23:49:34.886447 [ 3402 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:34.887987 [ 30720 ] {447430c3-6d5d-4827-9812-1a55ee8d8b96} TCPHandler: Code: 42. DB::Exception: Function isValidJSON needs exactly one argument: In scope SELECT isValidJSON(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:35.100505 [ 30720 ] {6b8c4c25-c1ad-4d8e-928b-eb6ebfb0b541} executeQuery: Code: 42. DB::Exception: Number of arguments for function isValidUTF8 doesn't match: passed 3, should be 1: In scope SELECT isValidUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT isValidUTF8(NULL, NULL, NULL);) 2025.10.23 23:49:35.103324 [ 30720 ] {6b8c4c25-c1ad-4d8e-928b-eb6ebfb0b541} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isValidUTF8 doesn't match: passed 3, should be 1: In scope SELECT isValidUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:35.129654 [ 30720 ] {9c46dfe2-be3b-4e07-852f-a385bada0d70} executeQuery: Code: 42. DB::Exception: Number of arguments for function isZeroOrNull doesn't match: passed 3, should be 1: In scope SELECT isZeroOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT isZeroOrNull(NULL, NULL, NULL);) 2025.10.23 23:49:35.133621 [ 30720 ] {9c46dfe2-be3b-4e07-852f-a385bada0d70} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isZeroOrNull doesn't match: passed 3, should be 1: In scope SELECT isZeroOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:35.183679 [ 30720 ] {c3e4b095-d045-466c-8ee2-b8c9f032fbab} executeQuery: Code: 42. DB::Exception: Number of arguments for function jaroSimilarity doesn't match: passed 3, should be 2: In scope SELECT jaroSimilarity(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT jaroSimilarity(NULL, NULL, NULL);) 2025.10.23 23:49:35.187452 [ 30720 ] {c3e4b095-d045-466c-8ee2-b8c9f032fbab} TCPHandler: Code: 42. DB::Exception: Number of arguments for function jaroSimilarity doesn't match: passed 3, should be 2: In scope SELECT jaroSimilarity(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:35.223386 [ 30720 ] {3bc78106-df40-42e2-99c7-2adcc99aabda} executeQuery: Code: 42. DB::Exception: Number of arguments for function jaroWinklerSimilarity doesn't match: passed 3, should be 2: In scope SELECT jaroWinklerSimilarity(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT jaroWinklerSimilarity(NULL, NULL, NULL);) 2025.10.23 23:49:35.227147 [ 30720 ] {3bc78106-df40-42e2-99c7-2adcc99aabda} TCPHandler: Code: 42. DB::Exception: Number of arguments for function jaroWinklerSimilarity doesn't match: passed 3, should be 2: In scope SELECT jaroWinklerSimilarity(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:35.386269 [ 3387 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:35.386345 [ 3394 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:35.466566 [ 3388 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:35.474101 [ 30720 ] {ac3d707e-7042-40b7-8d28-2e7b931f42a6} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function joinGet, expected a const string.: In scope SELECT joinGet(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT joinGet(NULL, NULL, NULL);) 2025.10.23 23:49:35.478188 [ 30720 ] {ac3d707e-7042-40b7-8d28-2e7b931f42a6} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function joinGet, expected a const string.: In scope SELECT joinGet(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:49:35.592028 [ 3398 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:35.602734 [ 30720 ] {d60ecbe9-243d-4cfb-8d44-87f486e982d7} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function joinGet, expected a const string.: In scope SELECT joinGetOrNull(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT joinGetOrNull(NULL, NULL, NULL);) 2025.10.23 23:49:35.607001 [ 30720 ] {d60ecbe9-243d-4cfb-8d44-87f486e982d7} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function joinGet, expected a const string.: In scope SELECT joinGetOrNull(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:49:35.720343 [ 3380 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:35.855657 [ 30720 ] {925549ca-27f1-4231-9cce-e8d8f5c9ffef} executeQuery: Code: 42. DB::Exception: Number of arguments for function jumpConsistentHash doesn't match: passed 3, should be 2: In scope SELECT jumpConsistentHash(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT jumpConsistentHash(NULL, NULL, NULL);) 2025.10.23 23:49:35.860030 [ 30720 ] {925549ca-27f1-4231-9cce-e8d8f5c9ffef} TCPHandler: Code: 42. DB::Exception: Number of arguments for function jumpConsistentHash doesn't match: passed 3, should be 2: In scope SELECT jumpConsistentHash(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:35.888010 [ 3364 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:36.168519 [ 30720 ] {3207625c-9917-4688-8b81-47c8a02510c7} executeQuery: Code: 42. DB::Exception: Number of arguments for function kostikConsistentHash doesn't match: passed 3, should be 2: In scope SELECT kostikConsistentHash(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT kostikConsistentHash(NULL, NULL, NULL);) 2025.10.23 23:49:36.218883 [ 30720 ] {3207625c-9917-4688-8b81-47c8a02510c7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function kostikConsistentHash doesn't match: passed 3, should be 2: In scope SELECT kostikConsistentHash(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:36.387146 [ 3355 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:36.387146 [ 3325 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:36.470473 [ 3334 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:36.593098 [ 3356 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:36.721403 [ 3335 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:36.850650 [ 30720 ] {f303ba78-33c5-476f-93e6-c52044f9fdbb} executeQuery: Code: 36. DB::Exception: Offset must be an integer, 'Nullable(Nothing)' given. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT lagInFrame(NULL, NULL, NULL);) 2025.10.23 23:49:36.854575 [ 30720 ] {f303ba78-33c5-476f-93e6-c52044f9fdbb} TCPHandler: Code: 36. DB::Exception: Offset must be an integer, 'Nullable(Nothing)' given. (BAD_ARGUMENTS) 2025.10.23 23:49:36.889290 [ 3320 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:37.097004 [ 30720 ] {9136d433-67eb-4166-9f4b-151ade59617c} executeQuery: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT last_value_respect_nulls(NULL, NULL, NULL);) 2025.10.23 23:49:37.100795 [ 30720 ] {9136d433-67eb-4166-9f4b-151ade59617c} TCPHandler: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:37.137590 [ 30720 ] {fdb2e99a-32fc-4203-8ee0-7846733d63a7} executeQuery: Code: 42. DB::Exception: Number of arguments for function lower doesn't match: passed 3, should be 1: In scope SELECT lcase(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT lcase(NULL, NULL, NULL);) 2025.10.23 23:49:37.141995 [ 30720 ] {fdb2e99a-32fc-4203-8ee0-7846733d63a7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lower doesn't match: passed 3, should be 1: In scope SELECT lcase(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:37.243627 [ 30720 ] {3e430906-72a8-42a3-ba92-7f39c5021bac} executeQuery: Code: 42. DB::Exception: Number of arguments for function lcm doesn't match: passed 3, should be 2: In scope SELECT lcm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT lcm(NULL, NULL, NULL);) 2025.10.23 23:49:37.247214 [ 30720 ] {3e430906-72a8-42a3-ba92-7f39c5021bac} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lcm doesn't match: passed 3, should be 2: In scope SELECT lcm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:37.293417 [ 30720 ] {674a049c-1087-45ee-84e6-5adb41351ed1} executeQuery: Code: 36. DB::Exception: Offset must be an integer, 'Nullable(Nothing)' given. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT leadInFrame(NULL, NULL, NULL);) 2025.10.23 23:49:37.297065 [ 30720 ] {674a049c-1087-45ee-84e6-5adb41351ed1} TCPHandler: Code: 36. DB::Exception: Offset must be an integer, 'Nullable(Nothing)' given. (BAD_ARGUMENTS) 2025.10.23 23:49:37.470025 [ 30720 ] {35bd8ec2-aad4-4767-b246-459f4499874d} executeQuery: Code: 42. DB::Exception: Number of arguments for function left doesn't match: passed 3, should be 2: In scope SELECT left(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT left(NULL, NULL, NULL);) 2025.10.23 23:49:37.472937 [ 3313 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:37.473176 [ 3308 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:37.473294 [ 3294 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:37.473907 [ 30720 ] {35bd8ec2-aad4-4767-b246-459f4499874d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function left doesn't match: passed 3, should be 2: In scope SELECT left(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:37.594538 [ 3302 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:37.717398 [ 30720 ] {e7edd01c-ffa8-411a-af4f-a8a57d799e8e} executeQuery: Code: 42. DB::Exception: Number of arguments for function leftUTF8 doesn't match: passed 3, should be 2: In scope SELECT leftUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT leftUTF8(NULL, NULL, NULL);) 2025.10.23 23:49:37.722572 [ 3312 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:37.742731 [ 30720 ] {e7edd01c-ffa8-411a-af4f-a8a57d799e8e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function leftUTF8 doesn't match: passed 3, should be 2: In scope SELECT leftUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:37.890620 [ 3278 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:37.931143 [ 30720 ] {09770185-4747-4d99-8567-e97bdc1bc008} executeQuery: Code: 344. DB::Exception: Natural language processing function 'lemmatize' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT lemmatize(NULL, NULL, NULL);) 2025.10.23 23:49:37.935084 [ 30720 ] {09770185-4747-4d99-8567-e97bdc1bc008} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'lemmatize' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.10.23 23:49:37.979095 [ 30720 ] {9c1a3ae1-4e6c-497b-a567-ddd6a5182afe} executeQuery: Code: 42. DB::Exception: Number of arguments for function length doesn't match: passed 3, should be 1: In scope SELECT length(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT length(NULL, NULL, NULL);) 2025.10.23 23:49:38.026989 [ 30720 ] {9c1a3ae1-4e6c-497b-a567-ddd6a5182afe} TCPHandler: Code: 42. DB::Exception: Number of arguments for function length doesn't match: passed 3, should be 1: In scope SELECT length(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:38.134567 [ 30720 ] {c7ccdb40-7d66-4009-adea-709407d118a2} executeQuery: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 3, should be 1: In scope SELECT lengthUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT lengthUTF8(NULL, NULL, NULL);) 2025.10.23 23:49:38.138778 [ 30720 ] {c7ccdb40-7d66-4009-adea-709407d118a2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 3, should be 1: In scope SELECT lengthUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:38.178403 [ 30720 ] {ad886e77-f52e-473f-84c7-0da4ed45cc06} executeQuery: Code: 42. DB::Exception: Number of arguments for function less doesn't match: passed 3, should be 2: In scope SELECT less(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT less(NULL, NULL, NULL);) 2025.10.23 23:49:38.194842 [ 30720 ] {ad886e77-f52e-473f-84c7-0da4ed45cc06} TCPHandler: Code: 42. DB::Exception: Number of arguments for function less doesn't match: passed 3, should be 2: In scope SELECT less(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:38.263066 [ 30720 ] {a90fc04f-f1b4-488c-9394-8a0089b9287e} executeQuery: Code: 42. DB::Exception: Number of arguments for function lessOrEquals doesn't match: passed 3, should be 2: In scope SELECT lessOrEquals(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT lessOrEquals(NULL, NULL, NULL);) 2025.10.23 23:49:38.267145 [ 30720 ] {a90fc04f-f1b4-488c-9394-8a0089b9287e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lessOrEquals doesn't match: passed 3, should be 2: In scope SELECT lessOrEquals(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:38.299102 [ 30720 ] {b16c51cf-c220-43b5-826b-3f37ca7987c4} executeQuery: Code: 42. DB::Exception: Number of arguments for function editDistance doesn't match: passed 3, should be 2: In scope SELECT levenshteinDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT levenshteinDistance(NULL, NULL, NULL);) 2025.10.23 23:49:38.303086 [ 30720 ] {b16c51cf-c220-43b5-826b-3f37ca7987c4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function editDistance doesn't match: passed 3, should be 2: In scope SELECT levenshteinDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:38.334521 [ 30720 ] {5b513fa5-de3f-4c72-99ca-8bb915dec7ea} executeQuery: Code: 42. DB::Exception: Number of arguments for function editDistanceUTF8 doesn't match: passed 3, should be 2: In scope SELECT levenshteinDistanceUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT levenshteinDistanceUTF8(NULL, NULL, NULL);) 2025.10.23 23:49:38.338339 [ 30720 ] {5b513fa5-de3f-4c72-99ca-8bb915dec7ea} TCPHandler: Code: 42. DB::Exception: Number of arguments for function editDistanceUTF8 doesn't match: passed 3, should be 2: In scope SELECT levenshteinDistanceUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:38.463466 [ 30720 ] {e46c01fd-4981-4afc-8e64-08ebc0ffe46c} executeQuery: Code: 42. DB::Exception: Number of arguments for function lgamma doesn't match: passed 3, should be 1: In scope SELECT lgamma(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT lgamma(NULL, NULL, NULL);) 2025.10.23 23:49:38.474040 [ 3274 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:38.474258 [ 3264 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:38.474486 [ 3260 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:38.567273 [ 30720 ] {e46c01fd-4981-4afc-8e64-08ebc0ffe46c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lgamma doesn't match: passed 3, should be 1: In scope SELECT lgamma(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:38.595957 [ 3262 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:38.598552 [ 30720 ] {a9ba2f3e-7473-42a1-b021-82c62a9f32b5} executeQuery: Code: 42. DB::Exception: Number of arguments for function like doesn't match: passed 3, should be 2: In scope SELECT like(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT like(NULL, NULL, NULL);) 2025.10.23 23:49:38.602317 [ 30720 ] {a9ba2f3e-7473-42a1-b021-82c62a9f32b5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function like doesn't match: passed 3, should be 2: In scope SELECT like(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:38.635936 [ 30720 ] {afd2a81a-dcae-45e7-8c84-d28d88d3e0e0} executeQuery: Code: 42. DB::Exception: Number of arguments for function log doesn't match: passed 3, should be 1: In scope SELECT ln(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT ln(NULL, NULL, NULL);) 2025.10.23 23:49:38.639273 [ 30720 ] {afd2a81a-dcae-45e7-8c84-d28d88d3e0e0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log doesn't match: passed 3, should be 1: In scope SELECT ln(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:38.723520 [ 3246 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:38.794601 [ 30720 ] {a0473f4d-04e3-422d-9964-0e0033018346} executeQuery: Code: 42. DB::Exception: Number of arguments for function log doesn't match: passed 3, should be 1: In scope SELECT log(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT log(NULL, NULL, NULL);) 2025.10.23 23:49:38.798149 [ 30720 ] {a0473f4d-04e3-422d-9964-0e0033018346} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log doesn't match: passed 3, should be 1: In scope SELECT log(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:38.892011 [ 3259 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:38.973119 [ 30720 ] {d05b1ad0-44e9-4df3-9425-ac3a0fe78e07} executeQuery: Code: 42. DB::Exception: Number of arguments for function log10 doesn't match: passed 3, should be 1: In scope SELECT log10(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT log10(NULL, NULL, NULL);) 2025.10.23 23:49:38.976664 [ 30720 ] {d05b1ad0-44e9-4df3-9425-ac3a0fe78e07} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log10 doesn't match: passed 3, should be 1: In scope SELECT log10(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:39.000827 [ 30720 ] {ed35b3dd-a732-4343-b97a-af555d6461b5} executeQuery: Code: 42. DB::Exception: Number of arguments for function log1p doesn't match: passed 3, should be 1: In scope SELECT log1p(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT log1p(NULL, NULL, NULL);) 2025.10.23 23:49:39.003214 [ 30720 ] {ed35b3dd-a732-4343-b97a-af555d6461b5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log1p doesn't match: passed 3, should be 1: In scope SELECT log1p(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:39.026488 [ 30720 ] {1ec6c110-0711-4be0-ac99-15d42d906227} executeQuery: Code: 42. DB::Exception: Number of arguments for function log2 doesn't match: passed 3, should be 1: In scope SELECT log2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT log2(NULL, NULL, NULL);) 2025.10.23 23:49:39.028982 [ 30720 ] {1ec6c110-0711-4be0-ac99-15d42d906227} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log2 doesn't match: passed 3, should be 1: In scope SELECT log2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:39.074778 [ 30720 ] {445023e5-43d1-4214-a90b-87e95c60ed87} executeQuery: Code: 42. DB::Exception: Number of arguments for function logTrace doesn't match: passed 3, should be 1: In scope SELECT logTrace(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT logTrace(NULL, NULL, NULL);) 2025.10.23 23:49:39.077384 [ 30720 ] {445023e5-43d1-4214-a90b-87e95c60ed87} TCPHandler: Code: 42. DB::Exception: Number of arguments for function logTrace doesn't match: passed 3, should be 1: In scope SELECT logTrace(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:39.106074 [ 30720 ] {1241a4f7-9089-4598-9b3d-9c48b4227c3f} executeQuery: Code: 42. DB::Exception: Number of arguments for function lowCardinalityIndices doesn't match: passed 3, should be 1: In scope SELECT lowCardinalityIndices(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT lowCardinalityIndices(NULL, NULL, NULL);) 2025.10.23 23:49:39.109104 [ 30720 ] {1241a4f7-9089-4598-9b3d-9c48b4227c3f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lowCardinalityIndices doesn't match: passed 3, should be 1: In scope SELECT lowCardinalityIndices(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:39.172675 [ 30720 ] {10dec5b6-bbca-4747-8768-48d6f5811227} executeQuery: Code: 42. DB::Exception: Number of arguments for function lowCardinalityKeys doesn't match: passed 3, should be 1: In scope SELECT lowCardinalityKeys(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT lowCardinalityKeys(NULL, NULL, NULL);) 2025.10.23 23:49:39.176470 [ 30720 ] {10dec5b6-bbca-4747-8768-48d6f5811227} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lowCardinalityKeys doesn't match: passed 3, should be 1: In scope SELECT lowCardinalityKeys(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:39.274627 [ 30720 ] {966d359d-566b-4ea3-837e-3ad9a72a7ae3} executeQuery: Code: 42. DB::Exception: Number of arguments for function lower doesn't match: passed 3, should be 1: In scope SELECT lower(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT lower(NULL, NULL, NULL);) 2025.10.23 23:49:39.277355 [ 30720 ] {966d359d-566b-4ea3-837e-3ad9a72a7ae3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lower doesn't match: passed 3, should be 1: In scope SELECT lower(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:39.321695 [ 30720 ] {7c82229d-b7b3-4624-b9e5-85872890bf0f} executeQuery: Code: 42. DB::Exception: Number of arguments for function lowerUTF8 doesn't match: passed 3, should be 1: In scope SELECT lowerUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT lowerUTF8(NULL, NULL, NULL);) 2025.10.23 23:49:39.324330 [ 30720 ] {7c82229d-b7b3-4624-b9e5-85872890bf0f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lowerUTF8 doesn't match: passed 3, should be 1: In scope SELECT lowerUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:39.475223 [ 3235 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:39.475822 [ 3229 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:39.476351 [ 3237 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:39.593251 [ 3894 ] {40355e57-d79c-4ea6-850a-263f42435c74} executeQuery: Code: 57. DB::Exception: Table test_tboay68b.null_before already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:57498) (comment: 02302_column_decl_null_before_defaul_value.sql) (in query: CREATE TABLE null_before (`id` INT NULL DEFAULT 1) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 30500, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 470782279, compact_parts_max_bytes_to_buffer = 389557628, compact_parts_max_granules_to_buffer = 172, compact_parts_merge_max_bytes_to_prefetch_part = 23248924, merge_max_block_size = 775, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 3840539435, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 22625738, concurrent_part_removal_threshold = 93, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 61512, primary_key_compress_block_size = 20093), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:49:39.594926 [ 3894 ] {40355e57-d79c-4ea6-850a-263f42435c74} TCPHandler: Code: 57. DB::Exception: Table test_tboay68b.null_before already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:49:39.597184 [ 3222 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:39.712636 [ 29264 ] {9d9bae9b-75a5-4664-894c-54f5ba6a1fb9} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56900) (comment: 02302_column_decl_null_before_defaul_value.sql) (in query: DROP DATABASE IF EXISTS test_tboay68b ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:49:39.715441 [ 29264 ] {9d9bae9b-75a5-4664-894c-54f5ba6a1fb9} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:39.724693 [ 3215 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:39.893299 [ 3206 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:40.467275 [ 30720 ] {c419284e-0a1d-479a-a7ba-687fcf40326e} executeQuery: Code: 42. DB::Exception: Function map requires even number of arguments, but 3 given: In scope SELECT map(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT map(NULL, NULL, NULL);) 2025.10.23 23:49:40.469969 [ 30720 ] {c419284e-0a1d-479a-a7ba-687fcf40326e} TCPHandler: Code: 42. DB::Exception: Function map requires even number of arguments, but 3 given: In scope SELECT map(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:40.476093 [ 3156 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:40.476753 [ 3169 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:40.477361 [ 3153 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:40.598859 [ 3138 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:40.725838 [ 3157 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:40.750399 [ 30720 ] {66537ea2-8a55-4d05-be6c-3a29d331bde6} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapContains doesn't match: passed 3, should be 2: In scope SELECT mapContains(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT mapContains(NULL, NULL, NULL);) 2025.10.23 23:49:40.752659 [ 30720 ] {66537ea2-8a55-4d05-be6c-3a29d331bde6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapContains doesn't match: passed 3, should be 2: In scope SELECT mapContains(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:40.894354 [ 3126 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:41.180683 [ 30720 ] {51fd1693-d070-4106-8186-93cf607f4720} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapFromArrays doesn't match: passed 3, should be 2: In scope SELECT mapFromArrays(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT mapFromArrays(NULL, NULL, NULL);) 2025.10.23 23:49:41.183509 [ 30720 ] {51fd1693-d070-4106-8186-93cf607f4720} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapFromArrays doesn't match: passed 3, should be 2: In scope SELECT mapFromArrays(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:41.258543 [ 30720 ] {c3a74534-71fe-4d6a-8d23-d8e71201130d} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapKeys doesn't match: passed 3, should be 1: In scope SELECT mapKeys(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT mapKeys(NULL, NULL, NULL);) 2025.10.23 23:49:41.261135 [ 30720 ] {c3a74534-71fe-4d6a-8d23-d8e71201130d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapKeys doesn't match: passed 3, should be 1: In scope SELECT mapKeys(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:41.477196 [ 3113 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:41.477379 [ 3108 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:41.478465 [ 3131 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:41.600329 [ 3103 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:41.716590 [ 30720 ] {4c4d02b8-37a3-48bd-8c7d-b7177d81cb1e} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapUpdate doesn't match: passed 3, should be 2: In scope SELECT mapUpdate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT mapUpdate(NULL, NULL, NULL);) 2025.10.23 23:49:41.721184 [ 30720 ] {4c4d02b8-37a3-48bd-8c7d-b7177d81cb1e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapUpdate doesn't match: passed 3, should be 2: In scope SELECT mapUpdate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:41.727152 [ 3097 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:41.777217 [ 30720 ] {f8c8e7d4-d8da-41aa-91fe-f5cb0c13f018} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapValues doesn't match: passed 3, should be 1: In scope SELECT mapValues(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT mapValues(NULL, NULL, NULL);) 2025.10.23 23:49:41.781172 [ 30720 ] {f8c8e7d4-d8da-41aa-91fe-f5cb0c13f018} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapValues doesn't match: passed 3, should be 1: In scope SELECT mapValues(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:41.819454 [ 30720 ] {a395996f-cdb7-4e0a-9d70-d44738795a7a} executeQuery: Code: 42. DB::Exception: Number of arguments for function match doesn't match: passed 3, should be 2: In scope SELECT match(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT match(NULL, NULL, NULL);) 2025.10.23 23:49:41.823278 [ 30720 ] {a395996f-cdb7-4e0a-9d70-d44738795a7a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function match doesn't match: passed 3, should be 2: In scope SELECT match(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:41.862590 [ 30720 ] {be5ac9a6-d335-43c9-9f03-ada392529431} executeQuery: Code: 42. DB::Exception: Number of arguments for function materialize doesn't match: passed 3, should be 1: In scope SELECT materialize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT materialize(NULL, NULL, NULL);) 2025.10.23 23:49:41.895647 [ 3093 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:41.930970 [ 30720 ] {be5ac9a6-d335-43c9-9f03-ada392529431} TCPHandler: Code: 42. DB::Exception: Number of arguments for function materialize doesn't match: passed 3, should be 1: In scope SELECT materialize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:42.157693 [ 30720 ] {fcffdb76-1d7b-42cf-b6fa-2021c421c7f5} executeQuery: Code: 42. DB::Exception: Number of arguments for function max2 doesn't match: passed 3, should be 2: In scope SELECT max2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT max2(NULL, NULL, NULL);) 2025.10.23 23:49:42.161104 [ 30720 ] {fcffdb76-1d7b-42cf-b6fa-2021c421c7f5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function max2 doesn't match: passed 3, should be 2: In scope SELECT max2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:42.489106 [ 3081 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:42.489311 [ 3084 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:42.489423 [ 3092 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:42.601523 [ 3105 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:42.728466 [ 3058 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:42.897071 [ 3062 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:43.490090 [ 3060 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:43.490370 [ 3056 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:43.490760 [ 3067 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:43.602607 [ 3435 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:43.729614 [ 3418 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:43.898070 [ 3329 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:44.490913 [ 3560 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:44.491481 [ 3111 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:44.492459 [ 3544 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:44.604351 [ 3556 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:44.730675 [ 3565 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:44.899347 [ 3527 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:45.049760 [ 30720 ] {83ff84fe-ca4a-48aa-99be-7a9e4f574701} executeQuery: Code: 42. DB::Exception: Number of arguments for function min2 doesn't match: passed 3, should be 2: In scope SELECT min2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT min2(NULL, NULL, NULL);) 2025.10.23 23:49:45.052525 [ 30720 ] {83ff84fe-ca4a-48aa-99be-7a9e4f574701} TCPHandler: Code: 42. DB::Exception: Number of arguments for function min2 doesn't match: passed 3, should be 2: In scope SELECT min2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:45.380466 [ 30720 ] {27c8a960-b8ee-499b-99e4-0e97e51f3405} executeQuery: Code: 42. DB::Exception: Number of arguments for function minSampleSizeContinuous doesn't match: passed 3, should be 5: In scope SELECT minSampleSizeContinous(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT minSampleSizeContinous(NULL, NULL, NULL);) 2025.10.23 23:49:45.382955 [ 30720 ] {27c8a960-b8ee-499b-99e4-0e97e51f3405} TCPHandler: Code: 42. DB::Exception: Number of arguments for function minSampleSizeContinuous doesn't match: passed 3, should be 5: In scope SELECT minSampleSizeContinous(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:45.433113 [ 30720 ] {96bc9685-1344-4890-b0b7-0c88f7e34af6} executeQuery: Code: 42. DB::Exception: Number of arguments for function minSampleSizeContinuous doesn't match: passed 3, should be 5: In scope SELECT minSampleSizeContinuous(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT minSampleSizeContinuous(NULL, NULL, NULL);) 2025.10.23 23:49:45.435533 [ 30720 ] {96bc9685-1344-4890-b0b7-0c88f7e34af6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function minSampleSizeContinuous doesn't match: passed 3, should be 5: In scope SELECT minSampleSizeContinuous(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:45.465099 [ 30720 ] {51ea7cea-c438-4004-9702-88e8f0806676} executeQuery: Code: 42. DB::Exception: Number of arguments for function minSampleSizeConversion doesn't match: passed 3, should be 4: In scope SELECT minSampleSizeConversion(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT minSampleSizeConversion(NULL, NULL, NULL);) 2025.10.23 23:49:45.467571 [ 30720 ] {51ea7cea-c438-4004-9702-88e8f0806676} TCPHandler: Code: 42. DB::Exception: Number of arguments for function minSampleSizeConversion doesn't match: passed 3, should be 4: In scope SELECT minSampleSizeConversion(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:45.491948 [ 3554 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:45.492694 [ 3530 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:45.493752 [ 3525 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:45.549640 [ 30720 ] {691bc7d8-0325-471f-950e-43a0d610cea6} executeQuery: Code: 42. DB::Exception: Number of arguments for function minus doesn't match: passed 3, should be 2: In scope SELECT minus(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT minus(NULL, NULL, NULL);) 2025.10.23 23:49:45.553463 [ 30720 ] {691bc7d8-0325-471f-950e-43a0d610cea6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function minus doesn't match: passed 3, should be 2: In scope SELECT minus(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:45.615472 [ 3519 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:45.636581 [ 30720 ] {6213955e-17a9-4c31-bb15-b1d28c869507} executeQuery: Code: 42. DB::Exception: Number of arguments for function byteHammingDistance doesn't match: passed 3, should be 2: In scope SELECT mismatches(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT mismatches(NULL, NULL, NULL);) 2025.10.23 23:49:45.640492 [ 30720 ] {6213955e-17a9-4c31-bb15-b1d28c869507} TCPHandler: Code: 42. DB::Exception: Number of arguments for function byteHammingDistance doesn't match: passed 3, should be 2: In scope SELECT mismatches(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:45.671243 [ 30720 ] {34d0d500-615a-43c4-92a1-a948b33de947} executeQuery: Code: 42. DB::Exception: Number of arguments for function modulo doesn't match: passed 3, should be 2: In scope SELECT mod(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT mod(NULL, NULL, NULL);) 2025.10.23 23:49:45.675083 [ 30720 ] {34d0d500-615a-43c4-92a1-a948b33de947} TCPHandler: Code: 42. DB::Exception: Number of arguments for function modulo doesn't match: passed 3, should be 2: In scope SELECT mod(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:45.732236 [ 3516 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:45.786171 [ 30720 ] {b6623127-57ff-46af-99c7-ba4b7a5969a9} executeQuery: Code: 42. DB::Exception: Number of arguments for function modulo doesn't match: passed 3, should be 2: In scope SELECT modulo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT modulo(NULL, NULL, NULL);) 2025.10.23 23:49:45.788809 [ 30720 ] {b6623127-57ff-46af-99c7-ba4b7a5969a9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function modulo doesn't match: passed 3, should be 2: In scope SELECT modulo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:45.819658 [ 30720 ] {8dbc88c0-dfb4-4a8c-b361-f696809f8b6e} executeQuery: Code: 42. DB::Exception: Number of arguments for function moduloLegacy doesn't match: passed 3, should be 2: In scope SELECT moduloLegacy(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT moduloLegacy(NULL, NULL, NULL);) 2025.10.23 23:49:45.824162 [ 30720 ] {8dbc88c0-dfb4-4a8c-b361-f696809f8b6e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function moduloLegacy doesn't match: passed 3, should be 2: In scope SELECT moduloLegacy(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:45.858728 [ 30720 ] {a36070c6-2899-4c24-b3ab-258fbb1137ed} executeQuery: Code: 42. DB::Exception: Number of arguments for function moduloOrZero doesn't match: passed 3, should be 2: In scope SELECT moduloOrZero(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT moduloOrZero(NULL, NULL, NULL);) 2025.10.23 23:49:45.863048 [ 30720 ] {a36070c6-2899-4c24-b3ab-258fbb1137ed} TCPHandler: Code: 42. DB::Exception: Number of arguments for function moduloOrZero doesn't match: passed 3, should be 2: In scope SELECT moduloOrZero(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:45.892863 [ 30720 ] {df3e5e56-e78d-4af1-9eae-d7950b8224cf} executeQuery: Code: 42. DB::Exception: Number of arguments for function monthName doesn't match: passed 3, should be 1: In scope SELECT monthName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT monthName(NULL, NULL, NULL);) 2025.10.23 23:49:45.896483 [ 30720 ] {df3e5e56-e78d-4af1-9eae-d7950b8224cf} TCPHandler: Code: 42. DB::Exception: Number of arguments for function monthName doesn't match: passed 3, should be 1: In scope SELECT monthName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:45.900571 [ 3514 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:45.979636 [ 30720 ] {c2f79340-2cd5-4921-b312-6cbce52a8544} executeQuery: Code: 42. DB::Exception: Number of arguments for function mortonDecode doesn't match: passed 3, should be 2: In scope SELECT mortonDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT mortonDecode(NULL, NULL, NULL);) 2025.10.23 23:49:45.982761 [ 30720 ] {c2f79340-2cd5-4921-b312-6cbce52a8544} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mortonDecode doesn't match: passed 3, should be 2: In scope SELECT mortonDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:46.412531 [ 30720 ] {5b15d28a-140f-4559-9343-c562ddcb279c} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiMatchAllIndices doesn't match: passed 3, should be 2: In scope SELECT multiMatchAllIndices(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT multiMatchAllIndices(NULL, NULL, NULL);) 2025.10.23 23:49:46.415885 [ 30720 ] {5b15d28a-140f-4559-9343-c562ddcb279c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiMatchAllIndices doesn't match: passed 3, should be 2: In scope SELECT multiMatchAllIndices(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:46.493119 [ 3503 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:46.493577 [ 3501 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:46.494963 [ 3513 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:46.507214 [ 30720 ] {5f3fdebf-c7f1-437e-a5d6-ee3f2f1d42fb} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiMatchAny doesn't match: passed 3, should be 2: In scope SELECT multiMatchAny(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT multiMatchAny(NULL, NULL, NULL);) 2025.10.23 23:49:46.509796 [ 30720 ] {5f3fdebf-c7f1-437e-a5d6-ee3f2f1d42fb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiMatchAny doesn't match: passed 3, should be 2: In scope SELECT multiMatchAny(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:46.539334 [ 30720 ] {7fbd2e0e-ba83-45bc-ad08-c8316f15c414} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiMatchAnyIndex doesn't match: passed 3, should be 2: In scope SELECT multiMatchAnyIndex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT multiMatchAnyIndex(NULL, NULL, NULL);) 2025.10.23 23:49:46.541744 [ 30720 ] {7fbd2e0e-ba83-45bc-ad08-c8316f15c414} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiMatchAnyIndex doesn't match: passed 3, should be 2: In scope SELECT multiMatchAnyIndex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:46.571581 [ 30720 ] {5ce1df9a-134a-4cd6-b64e-b5ecdd7c6b2a} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositions doesn't match: passed 3, should be 2: In scope SELECT multiSearchAllPositions(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT multiSearchAllPositions(NULL, NULL, NULL);) 2025.10.23 23:49:46.574222 [ 30720 ] {5ce1df9a-134a-4cd6-b64e-b5ecdd7c6b2a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositions doesn't match: passed 3, should be 2: In scope SELECT multiSearchAllPositions(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:46.624009 [ 3504 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:46.718428 [ 30720 ] {4c98cd9b-8df9-432c-9b44-f6234154c99e} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT multiSearchAllPositionsCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT multiSearchAllPositionsCaseInsensitive(NULL, NULL, NULL);) 2025.10.23 23:49:46.722168 [ 30720 ] {4c98cd9b-8df9-432c-9b44-f6234154c99e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT multiSearchAllPositionsCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:46.733301 [ 3502 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:46.792297 [ 30720 ] {44464625-93fe-4c7c-9888-21020ec24c62} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchAllPositionsCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT multiSearchAllPositionsCaseInsensitiveUTF8(NULL, NULL, NULL);) 2025.10.23 23:49:46.796046 [ 30720 ] {44464625-93fe-4c7c-9888-21020ec24c62} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchAllPositionsCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:46.845447 [ 30720 ] {0edc666f-7926-4a49-b2e3-0bc5a73bebb5} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchAllPositionsUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT multiSearchAllPositionsUTF8(NULL, NULL, NULL);) 2025.10.23 23:49:46.849269 [ 30720 ] {0edc666f-7926-4a49-b2e3-0bc5a73bebb5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchAllPositionsUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:46.886466 [ 30720 ] {fbed0601-a4e9-4b72-ba11-597bf54ae9ad} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAny doesn't match: passed 3, should be 2: In scope SELECT multiSearchAny(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT multiSearchAny(NULL, NULL, NULL);) 2025.10.23 23:49:46.890218 [ 30720 ] {fbed0601-a4e9-4b72-ba11-597bf54ae9ad} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAny doesn't match: passed 3, should be 2: In scope SELECT multiSearchAny(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:46.901608 [ 3491 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:46.970928 [ 30720 ] {4d17707e-f715-4cbf-b709-27caf7e6b285} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT multiSearchAnyCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT multiSearchAnyCaseInsensitive(NULL, NULL, NULL);) 2025.10.23 23:49:46.974828 [ 30720 ] {4d17707e-f715-4cbf-b709-27caf7e6b285} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT multiSearchAnyCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:47.097384 [ 30720 ] {14ce6f10-419d-4487-89f2-3ab641bacfb3} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchAnyCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT multiSearchAnyCaseInsensitiveUTF8(NULL, NULL, NULL);) 2025.10.23 23:49:47.101137 [ 30720 ] {14ce6f10-419d-4487-89f2-3ab641bacfb3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchAnyCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:47.131597 [ 30720 ] {9f19ed3d-19c8-4974-b5b3-ebb990122ff2} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchAnyUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT multiSearchAnyUTF8(NULL, NULL, NULL);) 2025.10.23 23:49:47.184851 [ 30720 ] {9f19ed3d-19c8-4974-b5b3-ebb990122ff2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchAnyUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:47.220985 [ 30720 ] {ee796bbc-212b-4066-bac8-22b0784d541c} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndex doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstIndex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT multiSearchFirstIndex(NULL, NULL, NULL);) 2025.10.23 23:49:47.223671 [ 30720 ] {ee796bbc-212b-4066-bac8-22b0784d541c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndex doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstIndex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:47.249018 [ 30720 ] {bd6877df-3347-46ce-aeae-9c327e40a1cc} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstIndexCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT multiSearchFirstIndexCaseInsensitive(NULL, NULL, NULL);) 2025.10.23 23:49:47.252105 [ 30720 ] {bd6877df-3347-46ce-aeae-9c327e40a1cc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstIndexCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:47.281552 [ 30720 ] {25c4a9ab-00a2-42ba-ae47-cd6fa7c490bb} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstIndexCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT multiSearchFirstIndexCaseInsensitiveUTF8(NULL, NULL, NULL);) 2025.10.23 23:49:47.284211 [ 30720 ] {25c4a9ab-00a2-42ba-ae47-cd6fa7c490bb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstIndexCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:47.312252 [ 30720 ] {5e092c2d-b446-4b37-831f-d2f829da73d8} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstIndexUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT multiSearchFirstIndexUTF8(NULL, NULL, NULL);) 2025.10.23 23:49:47.314515 [ 30720 ] {5e092c2d-b446-4b37-831f-d2f829da73d8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstIndexUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:47.430108 [ 30720 ] {a9438635-269f-4861-ac44-bc6af653d2b6} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPosition doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstPosition(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT multiSearchFirstPosition(NULL, NULL, NULL);) 2025.10.23 23:49:47.433891 [ 30720 ] {a9438635-269f-4861-ac44-bc6af653d2b6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPosition doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstPosition(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:47.463171 [ 30720 ] {b28ed69c-202f-4f4c-b634-6d1d790f5ef1} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstPositionCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT multiSearchFirstPositionCaseInsensitive(NULL, NULL, NULL);) 2025.10.23 23:49:47.466731 [ 30720 ] {b28ed69c-202f-4f4c-b634-6d1d790f5ef1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstPositionCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:47.494274 [ 3489 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:47.494506 [ 3477 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:47.500630 [ 30720 ] {7c898614-4b67-4c97-ac85-9b7cad25d749} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstPositionCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT multiSearchFirstPositionCaseInsensitiveUTF8(NULL, NULL, NULL);) 2025.10.23 23:49:47.505031 [ 30720 ] {7c898614-4b67-4c97-ac85-9b7cad25d749} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstPositionCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:47.541733 [ 3490 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:47.542209 [ 30720 ] {b1a538b5-2874-4b48-b50a-06aecf253d57} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstPositionUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT multiSearchFirstPositionUTF8(NULL, NULL, NULL);) 2025.10.23 23:49:47.546028 [ 30720 ] {b1a538b5-2874-4b48-b50a-06aecf253d57} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstPositionUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:47.582624 [ 30720 ] {bc76591c-210c-44e2-a7ed-c0413a93ca2e} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiply doesn't match: passed 3, should be 2: In scope SELECT multiply(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT multiply(NULL, NULL, NULL);) 2025.10.23 23:49:47.586756 [ 30720 ] {bc76591c-210c-44e2-a7ed-c0413a93ca2e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiply doesn't match: passed 3, should be 2: In scope SELECT multiply(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:47.625484 [ 3480 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:47.734507 [ 3471 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:47.902681 [ 3465 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:48.173394 [ 30720 ] {2c0a6462-0433-4121-bd6b-cd93cae6f4ea} executeQuery: Code: 42. DB::Exception: Number of arguments for function negate doesn't match: passed 3, should be 1: In scope SELECT negate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT negate(NULL, NULL, NULL);) 2025.10.23 23:49:48.176000 [ 30720 ] {2c0a6462-0433-4121-bd6b-cd93cae6f4ea} TCPHandler: Code: 42. DB::Exception: Number of arguments for function negate doesn't match: passed 3, should be 1: In scope SELECT negate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:48.207665 [ 30720 ] {5221d444-4510-4e55-8607-863f481bea49} executeQuery: Code: 721. DB::Exception: Function neighbor is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT neighbor(NULL, NULL, NULL);) 2025.10.23 23:49:48.210547 [ 30720 ] {5221d444-4510-4e55-8607-863f481bea49} TCPHandler: Code: 721. DB::Exception: Function neighbor is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) 2025.10.23 23:49:48.383539 [ 30720 ] {ee5dad22-22d2-4e9d-85d0-08a75d29e60c} executeQuery: Code: 42. DB::Exception: Number of arguments for function netloc doesn't match: passed 3, should be 1: In scope SELECT netloc(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT netloc(NULL, NULL, NULL);) 2025.10.23 23:49:48.386221 [ 30720 ] {ee5dad22-22d2-4e9d-85d0-08a75d29e60c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function netloc doesn't match: passed 3, should be 1: In scope SELECT netloc(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:48.414655 [ 30720 ] {07344c1b-8f70-41de-8fd6-70034002d7e0} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramDistance doesn't match: passed 3, should be 2: In scope SELECT ngramDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT ngramDistance(NULL, NULL, NULL);) 2025.10.23 23:49:48.417380 [ 30720 ] {07344c1b-8f70-41de-8fd6-70034002d7e0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramDistance doesn't match: passed 3, should be 2: In scope SELECT ngramDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:48.444205 [ 30720 ] {52a9d1b0-bfd8-4597-a6bb-99eb2f8d2c72} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramDistanceCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT ngramDistanceCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT ngramDistanceCaseInsensitive(NULL, NULL, NULL);) 2025.10.23 23:49:48.446616 [ 30720 ] {52a9d1b0-bfd8-4597-a6bb-99eb2f8d2c72} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramDistanceCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT ngramDistanceCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:48.495483 [ 3462 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:48.495567 [ 3454 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:48.506189 [ 30720 ] {98729669-f400-406b-bee0-ac4c833a523c} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramDistanceCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT ngramDistanceCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT ngramDistanceCaseInsensitiveUTF8(NULL, NULL, NULL);) 2025.10.23 23:49:48.509053 [ 30720 ] {98729669-f400-406b-bee0-ac4c833a523c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramDistanceCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT ngramDistanceCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:48.542813 [ 3450 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:48.561251 [ 30720 ] {21966c84-961c-4dc7-bbda-e9a4007838dc} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramDistanceUTF8 doesn't match: passed 3, should be 2: In scope SELECT ngramDistanceUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT ngramDistanceUTF8(NULL, NULL, NULL);) 2025.10.23 23:49:48.563796 [ 30720 ] {21966c84-961c-4dc7-bbda-e9a4007838dc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramDistanceUTF8 doesn't match: passed 3, should be 2: In scope SELECT ngramDistanceUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:48.626743 [ 3449 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:48.735879 [ 3429 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:48.904098 [ 3423 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:49.193613 [ 3648 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {959c1387-6a29-41af-9a70-593d11e44aac::202510_1_122_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 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) @ 0x0000000039c89948 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000003999bfb7 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 @ 0x00000000399942f0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000039d15c04 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&) @ 0x0000000039d20399 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) @ 0x0000000039d1c606 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000396308a4 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x00000000396235dd 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000003963b3e0 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x00000000396504a0 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3c455d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:49.305601 [ 30720 ] {9db0babf-7365-41ec-8e1a-2aa1697eec85} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramSearch doesn't match: passed 3, should be 2: In scope SELECT ngramSearch(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT ngramSearch(NULL, NULL, NULL);) 2025.10.23 23:49:49.308626 [ 30720 ] {9db0babf-7365-41ec-8e1a-2aa1697eec85} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramSearch doesn't match: passed 3, should be 2: In scope SELECT ngramSearch(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:49.413537 [ 30720 ] {1de6e90a-adda-46bd-8c64-14e61a4f6505} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramSearchCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT ngramSearchCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT ngramSearchCaseInsensitive(NULL, NULL, NULL);) 2025.10.23 23:49:49.416371 [ 30720 ] {1de6e90a-adda-46bd-8c64-14e61a4f6505} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramSearchCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT ngramSearchCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:49.496564 [ 3413 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:49.497171 [ 3424 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:49.539587 [ 30720 ] {9a3b38d6-87ac-4c3e-b487-c800d7f50c2f} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramSearchCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT ngramSearchCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT ngramSearchCaseInsensitiveUTF8(NULL, NULL, NULL);) 2025.10.23 23:49:49.542661 [ 30720 ] {9a3b38d6-87ac-4c3e-b487-c800d7f50c2f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramSearchCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT ngramSearchCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:49.544330 [ 3410 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:49.573796 [ 30720 ] {a5f59067-67d9-46fd-b785-4beca1678293} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramSearchUTF8 doesn't match: passed 3, should be 2: In scope SELECT ngramSearchUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT ngramSearchUTF8(NULL, NULL, NULL);) 2025.10.23 23:49:49.576530 [ 30720 ] {a5f59067-67d9-46fd-b785-4beca1678293} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramSearchUTF8 doesn't match: passed 3, should be 2: In scope SELECT ngramSearchUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:49.654197 [ 3412 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:49.736919 [ 3393 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:49.905516 [ 3403 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:50.497698 [ 3387 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:50.498289 [ 3394 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:50.533832 [ 30720 ] {a6868713-3b16-4f0d-82b5-be070f3720a9} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngrams doesn't match: passed 3, should be 2: In scope SELECT ngrams(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT ngrams(NULL, NULL, NULL);) 2025.10.23 23:49:50.545638 [ 3388 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:50.580524 [ 30720 ] {a6868713-3b16-4f0d-82b5-be070f3720a9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngrams doesn't match: passed 3, should be 2: In scope SELECT ngrams(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:50.605650 [ 30720 ] {1a240f59-6ae1-4b07-8566-9d58807679cd} executeQuery: Code: 36. DB::Exception: Argument 0 must be a number, 'Nullable(Nothing)' given. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT nonNegativeDerivative(NULL, NULL, NULL);) 2025.10.23 23:49:50.608340 [ 30720 ] {1a240f59-6ae1-4b07-8566-9d58807679cd} TCPHandler: Code: 36. DB::Exception: Argument 0 must be a number, 'Nullable(Nothing)' given. (BAD_ARGUMENTS) 2025.10.23 23:49:50.655535 [ 3377 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:50.706674 [ 30720 ] {8292907d-5849-4410-a584-90ea59211c4e} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Norm doesn't match: passed 3, should be 1: In scope SELECT normL1(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT normL1(NULL, NULL, NULL);) 2025.10.23 23:49:50.709503 [ 30720 ] {8292907d-5849-4410-a584-90ea59211c4e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Norm doesn't match: passed 3, should be 1: In scope SELECT normL1(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:50.733218 [ 30720 ] {49662265-4fa3-4ff0-8485-f56ea342e1f3} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Norm doesn't match: passed 3, should be 1: In scope SELECT normL2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT normL2(NULL, NULL, NULL);) 2025.10.23 23:49:50.735997 [ 30720 ] {49662265-4fa3-4ff0-8485-f56ea342e1f3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Norm doesn't match: passed 3, should be 1: In scope SELECT normL2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:50.738040 [ 3378 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:50.771467 [ 30720 ] {6c57de86-a2f6-48d4-ac5d-367d9573a7d0} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2SquaredNorm doesn't match: passed 3, should be 1: In scope SELECT normL2Squared(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT normL2Squared(NULL, NULL, NULL);) 2025.10.23 23:49:50.836007 [ 30720 ] {6c57de86-a2f6-48d4-ac5d-367d9573a7d0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2SquaredNorm doesn't match: passed 3, should be 1: In scope SELECT normL2Squared(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:50.906785 [ 3374 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:50.940707 [ 30720 ] {cf26ceee-87a6-4290-9544-35da04522d0e} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfNorm doesn't match: passed 3, should be 1: In scope SELECT normLinf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT normLinf(NULL, NULL, NULL);) 2025.10.23 23:49:50.944756 [ 30720 ] {cf26ceee-87a6-4290-9544-35da04522d0e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfNorm doesn't match: passed 3, should be 1: In scope SELECT normLinf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:51.132794 [ 30720 ] {d604ac08-f345-4a02-b291-99f383bd1f8d} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpNorm doesn't match: passed 3, should be 2: In scope SELECT normLp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT normLp(NULL, NULL, NULL);) 2025.10.23 23:49:51.136351 [ 30720 ] {d604ac08-f345-4a02-b291-99f383bd1f8d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpNorm doesn't match: passed 3, should be 2: In scope SELECT normLp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:51.160166 [ 30720 ] {77a0f441-be50-43a0-8269-6f82abf6a94e} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Normalize doesn't match: passed 3, should be 1: In scope SELECT normalizeL1(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT normalizeL1(NULL, NULL, NULL);) 2025.10.23 23:49:51.162674 [ 30720 ] {77a0f441-be50-43a0-8269-6f82abf6a94e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Normalize doesn't match: passed 3, should be 1: In scope SELECT normalizeL1(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:51.185908 [ 30720 ] {75780c7f-a6dd-4a6d-bbc8-7df3ab29171b} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Normalize doesn't match: passed 3, should be 1: In scope SELECT normalizeL2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT normalizeL2(NULL, NULL, NULL);) 2025.10.23 23:49:51.188597 [ 30720 ] {75780c7f-a6dd-4a6d-bbc8-7df3ab29171b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Normalize doesn't match: passed 3, should be 1: In scope SELECT normalizeL2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:51.212286 [ 30720 ] {e1944eb8-8f60-49e6-be11-22ed0215478a} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfNormalize doesn't match: passed 3, should be 1: In scope SELECT normalizeLinf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT normalizeLinf(NULL, NULL, NULL);) 2025.10.23 23:49:51.215022 [ 30720 ] {e1944eb8-8f60-49e6-be11-22ed0215478a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfNormalize doesn't match: passed 3, should be 1: In scope SELECT normalizeLinf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:51.238939 [ 30720 ] {1a77af26-aaf4-43bb-a646-435d925f35f6} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpNormalize doesn't match: passed 3, should be 2: In scope SELECT normalizeLp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT normalizeLp(NULL, NULL, NULL);) 2025.10.23 23:49:51.241678 [ 30720 ] {1a77af26-aaf4-43bb-a646-435d925f35f6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpNormalize doesn't match: passed 3, should be 2: In scope SELECT normalizeLp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:51.265664 [ 30720 ] {86abd9d0-2704-4e50-8073-07aff0b65912} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeQuery doesn't match: passed 3, should be 1: In scope SELECT normalizeQuery(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT normalizeQuery(NULL, NULL, NULL);) 2025.10.23 23:49:51.268440 [ 30720 ] {86abd9d0-2704-4e50-8073-07aff0b65912} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeQuery doesn't match: passed 3, should be 1: In scope SELECT normalizeQuery(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:51.329171 [ 30720 ] {ba3266ff-cb11-4efd-b999-6ecb87c91a79} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeQueryKeepNames doesn't match: passed 3, should be 1: In scope SELECT normalizeQueryKeepNames(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT normalizeQueryKeepNames(NULL, NULL, NULL);) 2025.10.23 23:49:51.332027 [ 30720 ] {ba3266ff-cb11-4efd-b999-6ecb87c91a79} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeQueryKeepNames doesn't match: passed 3, should be 1: In scope SELECT normalizeQueryKeepNames(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:51.445632 [ 30720 ] {8b58b1f8-74a8-4a7a-b45d-fa00d68b4411} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFC doesn't match: passed 3, should be 1: In scope SELECT normalizeUTF8NFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT normalizeUTF8NFC(NULL, NULL, NULL);) 2025.10.23 23:49:51.448641 [ 30720 ] {8b58b1f8-74a8-4a7a-b45d-fa00d68b4411} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFC doesn't match: passed 3, should be 1: In scope SELECT normalizeUTF8NFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:51.476536 [ 30720 ] {63fbf5e3-1864-4a8e-87f1-9f1bae79b91b} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFD doesn't match: passed 3, should be 1: In scope SELECT normalizeUTF8NFD(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT normalizeUTF8NFD(NULL, NULL, NULL);) 2025.10.23 23:49:51.480492 [ 30720 ] {63fbf5e3-1864-4a8e-87f1-9f1bae79b91b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFD doesn't match: passed 3, should be 1: In scope SELECT normalizeUTF8NFD(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:51.498834 [ 3361 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:51.499151 [ 3359 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:51.547154 [ 3358 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:51.563540 [ 30720 ] {842eda6f-e662-48cd-9c7e-9e5c152655d6} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFKC doesn't match: passed 3, should be 1: In scope SELECT normalizeUTF8NFKC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT normalizeUTF8NFKC(NULL, NULL, NULL);) 2025.10.23 23:49:51.567365 [ 30720 ] {842eda6f-e662-48cd-9c7e-9e5c152655d6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFKC doesn't match: passed 3, should be 1: In scope SELECT normalizeUTF8NFKC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:51.597682 [ 30720 ] {4a800e7f-b9bd-48ae-a3ee-7201f0f12ecb} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFKD doesn't match: passed 3, should be 1: In scope SELECT normalizeUTF8NFKD(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT normalizeUTF8NFKD(NULL, NULL, NULL);) 2025.10.23 23:49:51.601566 [ 30720 ] {4a800e7f-b9bd-48ae-a3ee-7201f0f12ecb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFKD doesn't match: passed 3, should be 1: In scope SELECT normalizeUTF8NFKD(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:51.657104 [ 3373 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:51.739476 [ 3346 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:51.818460 [ 30720 ] {32883042-546a-489d-8b12-75534059350a} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizedQueryHash doesn't match: passed 3, should be 1: In scope SELECT normalizedQueryHash(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT normalizedQueryHash(NULL, NULL, NULL);) 2025.10.23 23:49:51.822569 [ 30720 ] {32883042-546a-489d-8b12-75534059350a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizedQueryHash doesn't match: passed 3, should be 1: In scope SELECT normalizedQueryHash(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:51.908235 [ 3343 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:51.926009 [ 30720 ] {3bd137c3-f146-449b-bf20-36baa38c2e25} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizedQueryHashKeepNames doesn't match: passed 3, should be 1: In scope SELECT normalizedQueryHashKeepNames(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT normalizedQueryHashKeepNames(NULL, NULL, NULL);) 2025.10.23 23:49:51.928782 [ 30720 ] {3bd137c3-f146-449b-bf20-36baa38c2e25} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizedQueryHashKeepNames doesn't match: passed 3, should be 1: In scope SELECT normalizedQueryHashKeepNames(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:51.955477 [ 30720 ] {a10ad941-4ebf-4841-85d4-197c76954fe2} executeQuery: Code: 42. DB::Exception: Number of arguments for function not doesn't match: passed 3, should be 1: In scope SELECT not(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT not(NULL, NULL, NULL);) 2025.10.23 23:49:51.959330 [ 30720 ] {a10ad941-4ebf-4841-85d4-197c76954fe2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function not doesn't match: passed 3, should be 1: In scope SELECT not(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:51.991117 [ 30720 ] {7c9a36fb-6b4d-4304-be51-89ec8a986c45} executeQuery: Code: 42. DB::Exception: Number of arguments for function notEmpty doesn't match: passed 3, should be 1: In scope SELECT notEmpty(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT notEmpty(NULL, NULL, NULL);) 2025.10.23 23:49:51.995063 [ 30720 ] {7c9a36fb-6b4d-4304-be51-89ec8a986c45} TCPHandler: Code: 42. DB::Exception: Number of arguments for function notEmpty doesn't match: passed 3, should be 1: In scope SELECT notEmpty(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:52.026297 [ 30720 ] {89133950-4588-44c1-8e33-8e79b98fc6c7} executeQuery: Code: 42. DB::Exception: Number of arguments for function notEquals doesn't match: passed 3, should be 2: In scope SELECT notEquals(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT notEquals(NULL, NULL, NULL);) 2025.10.23 23:49:52.029948 [ 30720 ] {89133950-4588-44c1-8e33-8e79b98fc6c7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function notEquals doesn't match: passed 3, should be 2: In scope SELECT notEquals(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:52.063398 [ 30720 ] {67058317-6570-4bd0-ba3a-7a642aee738e} executeQuery: Code: 42. DB::Exception: Number of arguments for function notILike doesn't match: passed 3, should be 2: In scope SELECT notILike(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT notILike(NULL, NULL, NULL);) 2025.10.23 23:49:52.067135 [ 30720 ] {67058317-6570-4bd0-ba3a-7a642aee738e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function notILike doesn't match: passed 3, should be 2: In scope SELECT notILike(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:52.099884 [ 30720 ] {a0ae6355-bd5e-4bb9-8012-da192b7185d0} executeQuery: Code: 42. DB::Exception: Function 'notIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT notIn(NULL, NULL, NULL);) 2025.10.23 23:49:52.103370 [ 30720 ] {a0ae6355-bd5e-4bb9-8012-da192b7185d0} TCPHandler: Code: 42. DB::Exception: Function 'notIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:52.137134 [ 30720 ] {207478e8-bc72-4597-9d3c-cce2e41f27ec} executeQuery: Code: 42. DB::Exception: Function 'notInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT notInIgnoreSet(NULL, NULL, NULL);) 2025.10.23 23:49:52.140787 [ 30720 ] {207478e8-bc72-4597-9d3c-cce2e41f27ec} TCPHandler: Code: 42. DB::Exception: Function 'notInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:52.175469 [ 30720 ] {5f982a1d-14e5-4d68-84d2-701082750620} executeQuery: Code: 42. DB::Exception: Number of arguments for function notLike doesn't match: passed 3, should be 2: In scope SELECT notLike(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT notLike(NULL, NULL, NULL);) 2025.10.23 23:49:52.179118 [ 30720 ] {5f982a1d-14e5-4d68-84d2-701082750620} TCPHandler: Code: 42. DB::Exception: Number of arguments for function notLike doesn't match: passed 3, should be 2: In scope SELECT notLike(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:52.246090 [ 30720 ] {57d95869-eb6b-480c-8f8b-6535779ad747} executeQuery: Code: 42. DB::Exception: Function 'notNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT notNullIn(NULL, NULL, NULL);) 2025.10.23 23:49:52.250050 [ 30720 ] {57d95869-eb6b-480c-8f8b-6535779ad747} TCPHandler: Code: 42. DB::Exception: Function 'notNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:52.288441 [ 30720 ] {96bcd2ac-11a0-403f-aa9b-a4a573eca2a1} executeQuery: Code: 42. DB::Exception: Function 'notNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT notNullInIgnoreSet(NULL, NULL, NULL);) 2025.10.23 23:49:52.292368 [ 30720 ] {96bcd2ac-11a0-403f-aa9b-a4a573eca2a1} TCPHandler: Code: 42. DB::Exception: Function 'notNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:52.500130 [ 3330 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:52.500372 [ 3365 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:52.548540 [ 3350 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:52.658167 [ 3356 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:52.676467 [ 30720 ] {ba84253f-498e-4c37-9c64-e23d92a59eb8} executeQuery: Code: 42. DB::Exception: Arguments size of function now should be 0 or 1: In scope SELECT now(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT now(NULL, NULL, NULL);) 2025.10.23 23:49:52.680496 [ 30720 ] {ba84253f-498e-4c37-9c64-e23d92a59eb8} TCPHandler: Code: 42. DB::Exception: Arguments size of function now should be 0 or 1: In scope SELECT now(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:52.740631 [ 3341 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:52.804895 [ 30720 ] {895ce5a3-f32b-4211-8ecb-bd72b5568dc2} executeQuery: Code: 42. DB::Exception: Function nth_value takes exactly two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT nth_value(NULL, NULL, NULL);) 2025.10.23 23:49:52.807465 [ 30720 ] {895ce5a3-f32b-4211-8ecb-bd72b5568dc2} TCPHandler: Code: 42. DB::Exception: Function nth_value takes exactly two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:52.909428 [ 3333 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:52.921621 [ 30720 ] {8b1d1ceb-1cc5-44d0-b510-8e68cbf47888} executeQuery: Code: 42. DB::Exception: Function ntile takes exactly one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT ntile(NULL, NULL, NULL);) 2025.10.23 23:49:52.924187 [ 30720 ] {8b1d1ceb-1cc5-44d0-b510-8e68cbf47888} TCPHandler: Code: 42. DB::Exception: Function ntile takes exactly one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:52.947114 [ 30720 ] {4db91b17-a317-4976-8251-f86d9d4a4dff} executeQuery: Code: 42. DB::Exception: Number of arguments for function nullIf doesn't match: passed 3, should be 2: In scope SELECT nullIf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT nullIf(NULL, NULL, NULL);) 2025.10.23 23:49:52.949767 [ 30720 ] {4db91b17-a317-4976-8251-f86d9d4a4dff} TCPHandler: Code: 42. DB::Exception: Number of arguments for function nullIf doesn't match: passed 3, should be 2: In scope SELECT nullIf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:52.972184 [ 30720 ] {9ad75385-5221-4f9c-a0f8-d74bc3317ff3} executeQuery: Code: 42. DB::Exception: Function 'nullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT nullIn(NULL, NULL, NULL);) 2025.10.23 23:49:52.974946 [ 30720 ] {9ad75385-5221-4f9c-a0f8-d74bc3317ff3} TCPHandler: Code: 42. DB::Exception: Function 'nullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:53.053948 [ 30720 ] {b7193465-bbf0-4f13-bd3b-ad395b07c9ab} executeQuery: Code: 42. DB::Exception: Function 'nullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT nullInIgnoreSet(NULL, NULL, NULL);) 2025.10.23 23:49:53.406755 [ 30720 ] {b7193465-bbf0-4f13-bd3b-ad395b07c9ab} TCPHandler: Code: 42. DB::Exception: Function 'nullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:53.501444 [ 3318 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:53.501459 [ 3307 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:53.549724 [ 3310 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:53.659191 [ 3309 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:53.741649 [ 3298 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:53.910699 [ 3294 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:54.502594 [ 3285 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:54.502865 [ 3287 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:54.550899 [ 3283 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:54.660675 [ 3277 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:54.743038 [ 3275 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:54.911926 [ 3269 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:55.484999 [ 30720 ] {0a66a9d1-27a7-4b6d-b891-e210433b8f42} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseReadableSize doesn't match: passed 3, should be 1: In scope SELECT parseReadableSize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT parseReadableSize(NULL, NULL, NULL);) 2025.10.23 23:49:55.487516 [ 30720 ] {0a66a9d1-27a7-4b6d-b891-e210433b8f42} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseReadableSize doesn't match: passed 3, should be 1: In scope SELECT parseReadableSize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:55.503565 [ 3260 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:55.504269 [ 3263 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:55.508728 [ 30720 ] {5ef975cb-0af5-427b-a570-e78552fcbd81} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseReadableSizeOrNull doesn't match: passed 3, should be 1: In scope SELECT parseReadableSizeOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT parseReadableSizeOrNull(NULL, NULL, NULL);) 2025.10.23 23:49:55.511493 [ 30720 ] {5ef975cb-0af5-427b-a570-e78552fcbd81} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseReadableSizeOrNull doesn't match: passed 3, should be 1: In scope SELECT parseReadableSizeOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:55.552418 [ 3252 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:55.565845 [ 30720 ] {c6dd439d-2cff-4d0b-8551-6c4bb8ecc68c} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseReadableSizeOrZero doesn't match: passed 3, should be 1: In scope SELECT parseReadableSizeOrZero(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT parseReadableSizeOrZero(NULL, NULL, NULL);) 2025.10.23 23:49:55.569035 [ 30720 ] {c6dd439d-2cff-4d0b-8551-6c4bb8ecc68c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseReadableSizeOrZero doesn't match: passed 3, should be 1: In scope SELECT parseReadableSizeOrZero(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:55.662057 [ 3253 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:55.744117 [ 3246 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:55.801613 [ 30720 ] {0417773a-7e1a-4285-8a62-e211a938d4cb} executeQuery: Code: 42. DB::Exception: Number of arguments for function path doesn't match: passed 3, should be 1: In scope SELECT path(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT path(NULL, NULL, NULL);) 2025.10.23 23:49:55.804319 [ 30720 ] {0417773a-7e1a-4285-8a62-e211a938d4cb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function path doesn't match: passed 3, should be 1: In scope SELECT path(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:55.826205 [ 30720 ] {e665c792-fa22-46df-9392-c48761e876f8} executeQuery: Code: 42. DB::Exception: Number of arguments for function pathFull doesn't match: passed 3, should be 1: In scope SELECT pathFull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT pathFull(NULL, NULL, NULL);) 2025.10.23 23:49:55.828639 [ 30720 ] {e665c792-fa22-46df-9392-c48761e876f8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function pathFull doesn't match: passed 3, should be 1: In scope SELECT pathFull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:55.872337 [ 30720 ] {e33c33fa-61de-428f-b69c-5cb2b7d10361} executeQuery: Code: 36. DB::Exception: The function 'percentRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT percentRank(NULL, NULL, NULL);) 2025.10.23 23:49:55.877634 [ 30720 ] {e33c33fa-61de-428f-b69c-5cb2b7d10361} TCPHandler: Code: 36. DB::Exception: The function 'percentRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.10.23 23:49:55.913021 [ 3259 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:56.011661 [ 30720 ] {4d2758ed-1234-46c5-b8f8-afe193915628} executeQuery: Code: 36. DB::Exception: The function 'percentRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT percent_rank(NULL, NULL, NULL);) 2025.10.23 23:49:56.017859 [ 30720 ] {4d2758ed-1234-46c5-b8f8-afe193915628} TCPHandler: Code: 36. DB::Exception: The function 'percentRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.10.23 23:49:56.048997 [ 30720 ] {7e2fbf6a-7d55-45fe-bc29-efa915cc6f1c} executeQuery: Code: 42. DB::Exception: Number of arguments for function pi doesn't match: passed 3, should be 0: In scope SELECT pi(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT pi(NULL, NULL, NULL);) 2025.10.23 23:49:56.052621 [ 30720 ] {7e2fbf6a-7d55-45fe-bc29-efa915cc6f1c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function pi doesn't match: passed 3, should be 0: In scope SELECT pi(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:56.226138 [ 30720 ] {c23ca641-448c-4f79-a2e2-3ab2ba223f4b} executeQuery: Code: 42. DB::Exception: Number of arguments for function plus doesn't match: passed 3, should be 2: In scope SELECT plus(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT plus(NULL, NULL, NULL);) 2025.10.23 23:49:56.230366 [ 30720 ] {c23ca641-448c-4f79-a2e2-3ab2ba223f4b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function plus doesn't match: passed 3, should be 2: In scope SELECT plus(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:56.396697 [ 30720 ] {a50773c9-bc02-44cd-8aaa-5d16f47c2ea7} executeQuery: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 3, should be 2: In scope SELECT pmod(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT pmod(NULL, NULL, NULL);) 2025.10.23 23:49:56.401512 [ 30720 ] {a50773c9-bc02-44cd-8aaa-5d16f47c2ea7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 3, should be 2: In scope SELECT pmod(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:56.504406 [ 3234 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:56.504986 [ 3234 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:56.546072 [ 3644 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {26a86919-b755-436d-800b-c04857d425d1::202510_1_160_82}: 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000002009b98d 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x000000002009675f 5. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:129: CurrentMemoryTracker::injectFault() @ 0x000000001ff7d1df 6. ./build_docker/./src/Common/ThreadFuzzer.cpp:270: DB::ThreadFuzzer::maybeInjectMemoryLimitException() @ 0x000000002011909f 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:151: DB::MergePlainMergeTreeTask::finish() @ 0x000000003a3c7732 8. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3c4534 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:56.553576 [ 3230 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:56.578968 [ 30720 ] {2e43a281-ba8a-4f8e-a4a5-d12a058424e7} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonAreaCartesian doesn't match: passed 3, should be 1: In scope SELECT polygonAreaCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT polygonAreaCartesian(NULL, NULL, NULL);) 2025.10.23 23:49:56.581994 [ 30720 ] {2e43a281-ba8a-4f8e-a4a5-d12a058424e7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonAreaCartesian doesn't match: passed 3, should be 1: In scope SELECT polygonAreaCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:56.663099 [ 3224 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:56.689213 [ 30720 ] {7e2746d3-2f57-4790-a23a-e27bf9914a74} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonAreaSpherical doesn't match: passed 3, should be 1: In scope SELECT polygonAreaSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT polygonAreaSpherical(NULL, NULL, NULL);) 2025.10.23 23:49:56.692328 [ 30720 ] {7e2746d3-2f57-4790-a23a-e27bf9914a74} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonAreaSpherical doesn't match: passed 3, should be 1: In scope SELECT polygonAreaSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:56.745027 [ 3218 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:56.771661 [ 30720 ] {b784bd4b-ee2d-493e-91be-ae28347873d2} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonConvexHullCartesian doesn't match: passed 3, should be 1: In scope SELECT polygonConvexHullCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT polygonConvexHullCartesian(NULL, NULL, NULL);) 2025.10.23 23:49:56.775567 [ 30720 ] {b784bd4b-ee2d-493e-91be-ae28347873d2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonConvexHullCartesian doesn't match: passed 3, should be 1: In scope SELECT polygonConvexHullCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:56.804920 [ 30720 ] {0eda3e90-96ed-4e63-ab2e-1916fb3f5ab6} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonPerimeterCartesian doesn't match: passed 3, should be 1: In scope SELECT polygonPerimeterCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT polygonPerimeterCartesian(NULL, NULL, NULL);) 2025.10.23 23:49:56.808692 [ 30720 ] {0eda3e90-96ed-4e63-ab2e-1916fb3f5ab6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonPerimeterCartesian doesn't match: passed 3, should be 1: In scope SELECT polygonPerimeterCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:56.853718 [ 30720 ] {13bea6d9-0dc3-47ee-aece-6896250ef97c} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonPerimeterSpherical doesn't match: passed 3, should be 1: In scope SELECT polygonPerimeterSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT polygonPerimeterSpherical(NULL, NULL, NULL);) 2025.10.23 23:49:56.857507 [ 30720 ] {13bea6d9-0dc3-47ee-aece-6896250ef97c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonPerimeterSpherical doesn't match: passed 3, should be 1: In scope SELECT polygonPerimeterSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:56.914251 [ 3211 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:56.953950 [ 30720 ] {4da961ac-c8d6-4f31-9c97-96606d0e30ca} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsDistanceCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsDistanceCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT polygonsDistanceCartesian(NULL, NULL, NULL);) 2025.10.23 23:49:56.957695 [ 30720 ] {4da961ac-c8d6-4f31-9c97-96606d0e30ca} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsDistanceCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsDistanceCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:56.985492 [ 30720 ] {cd7614b7-e7eb-4bf0-a77e-7855bd3ddb00} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsDistanceSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsDistanceSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT polygonsDistanceSpherical(NULL, NULL, NULL);) 2025.10.23 23:49:56.989143 [ 30720 ] {cd7614b7-e7eb-4bf0-a77e-7855bd3ddb00} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsDistanceSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsDistanceSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:57.018220 [ 30720 ] {e1076fc6-3671-4668-aea4-fb2f27f27321} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsEqualsCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsEqualsCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT polygonsEqualsCartesian(NULL, NULL, NULL);) 2025.10.23 23:49:57.021918 [ 30720 ] {e1076fc6-3671-4668-aea4-fb2f27f27321} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsEqualsCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsEqualsCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:57.149492 [ 30720 ] {f0f29d5c-2c9f-4d43-a3cf-2bb18fbe0e8b} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsIntersectionCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsIntersectionCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT polygonsIntersectionCartesian(NULL, NULL, NULL);) 2025.10.23 23:49:57.154270 [ 30720 ] {f0f29d5c-2c9f-4d43-a3cf-2bb18fbe0e8b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsIntersectionCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsIntersectionCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:57.344591 [ 30720 ] {b9491a03-9d5b-4d44-afcd-4695d2266118} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsIntersectionSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsIntersectionSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT polygonsIntersectionSpherical(NULL, NULL, NULL);) 2025.10.23 23:49:57.347423 [ 30720 ] {b9491a03-9d5b-4d44-afcd-4695d2266118} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsIntersectionSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsIntersectionSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:57.407198 [ 30720 ] {0c50108a-c909-4667-b982-9baf89e2f76d} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsSymDifferenceCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsSymDifferenceCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT polygonsSymDifferenceCartesian(NULL, NULL, NULL);) 2025.10.23 23:49:57.409746 [ 30720 ] {0c50108a-c909-4667-b982-9baf89e2f76d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsSymDifferenceCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsSymDifferenceCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:57.432604 [ 30720 ] {b47ce2c6-b39a-4124-8d3b-b5cd1a5680a4} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsSymDifferenceSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsSymDifferenceSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT polygonsSymDifferenceSpherical(NULL, NULL, NULL);) 2025.10.23 23:49:57.435016 [ 30720 ] {b47ce2c6-b39a-4124-8d3b-b5cd1a5680a4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsSymDifferenceSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsSymDifferenceSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:57.455653 [ 30720 ] {6b6d517f-17ea-4454-9209-c9208b28e77d} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsUnionCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsUnionCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT polygonsUnionCartesian(NULL, NULL, NULL);) 2025.10.23 23:49:57.458300 [ 30720 ] {6b6d517f-17ea-4454-9209-c9208b28e77d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsUnionCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsUnionCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:57.477949 [ 30720 ] {8e09ddf3-f531-401a-a6ca-d325363a45e7} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsUnionSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsUnionSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT polygonsUnionSpherical(NULL, NULL, NULL);) 2025.10.23 23:49:57.480364 [ 30720 ] {8e09ddf3-f531-401a-a6ca-d325363a45e7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsUnionSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsUnionSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:57.499501 [ 30720 ] {d844fb92-b5d7-4217-9b0a-e6f6197a5cfa} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsWithinCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsWithinCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT polygonsWithinCartesian(NULL, NULL, NULL);) 2025.10.23 23:49:57.501598 [ 30720 ] {d844fb92-b5d7-4217-9b0a-e6f6197a5cfa} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsWithinCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsWithinCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:57.505262 [ 3209 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:57.505727 [ 3208 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:57.520348 [ 30720 ] {4797004a-493e-4dc5-9cfe-0b5b703c44a0} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsWithinSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsWithinSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT polygonsWithinSpherical(NULL, NULL, NULL);) 2025.10.23 23:49:57.522607 [ 30720 ] {4797004a-493e-4dc5-9cfe-0b5b703c44a0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsWithinSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsWithinSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:57.554628 [ 3199 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:57.666907 [ 3205 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:57.746184 [ 3195 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:57.915527 [ 3191 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:58.010955 [ 30720 ] {84a5f91b-988f-4335-b1a6-6ced7c1f10f4} executeQuery: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 3, should be 2: In scope SELECT positiveModulo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT positiveModulo(NULL, NULL, NULL);) 2025.10.23 23:49:58.013608 [ 30720 ] {84a5f91b-988f-4335-b1a6-6ced7c1f10f4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 3, should be 2: In scope SELECT positiveModulo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:58.036485 [ 30720 ] {56a43dcd-5d5d-437e-942c-d43464419e08} executeQuery: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 3, should be 2: In scope SELECT positive_modulo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT positive_modulo(NULL, NULL, NULL);) 2025.10.23 23:49:58.039157 [ 30720 ] {56a43dcd-5d5d-437e-942c-d43464419e08} TCPHandler: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 3, should be 2: In scope SELECT positive_modulo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:58.060750 [ 30720 ] {ba700225-e594-4bf7-bc7a-00ca972be663} executeQuery: Code: 42. DB::Exception: Number of arguments for function pow doesn't match: passed 3, should be 2: In scope SELECT pow(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT pow(NULL, NULL, NULL);) 2025.10.23 23:49:58.063273 [ 30720 ] {ba700225-e594-4bf7-bc7a-00ca972be663} TCPHandler: Code: 42. DB::Exception: Number of arguments for function pow doesn't match: passed 3, should be 2: In scope SELECT pow(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:58.150442 [ 30720 ] {2af8ceba-7946-4e2a-b282-c8fab22c4009} executeQuery: Code: 42. DB::Exception: Number of arguments for function pow doesn't match: passed 3, should be 2: In scope SELECT power(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT power(NULL, NULL, NULL);) 2025.10.23 23:49:58.166969 [ 30720 ] {2af8ceba-7946-4e2a-b282-c8fab22c4009} TCPHandler: Code: 42. DB::Exception: Number of arguments for function pow doesn't match: passed 3, should be 2: In scope SELECT power(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:58.228852 [ 30720 ] {97624a1e-3b0f-4247-bd9a-7e7a040f93ec} executeQuery: Code: 42. DB::Exception: Number of arguments for function proportionsZTest doesn't match: passed 3, should be 6: In scope SELECT proportionsZTest(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT proportionsZTest(NULL, NULL, NULL);) 2025.10.23 23:49:58.231306 [ 30720 ] {97624a1e-3b0f-4247-bd9a-7e7a040f93ec} TCPHandler: Code: 42. DB::Exception: Number of arguments for function proportionsZTest doesn't match: passed 3, should be 6: In scope SELECT proportionsZTest(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:58.254969 [ 30720 ] {678a2ae9-77ec-4309-be7c-4268e1458965} executeQuery: Code: 42. DB::Exception: Number of arguments for function protocol doesn't match: passed 3, should be 1: In scope SELECT protocol(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT protocol(NULL, NULL, NULL);) 2025.10.23 23:49:58.258003 [ 30720 ] {678a2ae9-77ec-4309-be7c-4268e1458965} TCPHandler: Code: 42. DB::Exception: Number of arguments for function protocol doesn't match: passed 3, should be 1: In scope SELECT protocol(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:58.340933 [ 30720 ] {f42c71e9-5be9-4718-974a-e348aa5167e9} executeQuery: Code: 42. DB::Exception: Number of arguments for function punycodeDecode doesn't match: passed 3, should be 1: In scope SELECT punycodeDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT punycodeDecode(NULL, NULL, NULL);) 2025.10.23 23:49:58.343682 [ 30720 ] {f42c71e9-5be9-4718-974a-e348aa5167e9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function punycodeDecode doesn't match: passed 3, should be 1: In scope SELECT punycodeDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:58.366529 [ 30720 ] {69ef423a-44c6-4dbc-b16f-86c46f1414a7} executeQuery: Code: 42. DB::Exception: Number of arguments for function punycodeEncode doesn't match: passed 3, should be 1: In scope SELECT punycodeEncode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT punycodeEncode(NULL, NULL, NULL);) 2025.10.23 23:49:58.369179 [ 30720 ] {69ef423a-44c6-4dbc-b16f-86c46f1414a7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function punycodeEncode doesn't match: passed 3, should be 1: In scope SELECT punycodeEncode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:49:58.506247 [ 3179 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:58.506489 [ 3173 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:58.555996 [ 3182 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:58.667894 [ 3176 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:58.747283 [ 3166 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:58.916947 [ 3169 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:59.248225 [ 30720 ] {13de8ae3-5152-4462-beb9-ee3d0687ea40} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=748). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT quantileExactWeighted(NULL, NULL, NULL);) 2025.10.23 23:49:59.251830 [ 30720 ] {13de8ae3-5152-4462-beb9-ee3d0687ea40} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=748). (CANNOT_SCHEDULE_TASK) 2025.10.23 23:49:59.507104 [ 3517 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:59.507273 [ 3139 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:59.557021 [ 3147 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:59.668708 [ 3144 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:59.721466 [ 30720 ] {1ffe1ca5-e256-4fb0-b703-e90e447cf359} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT quantileTDigestWeighted(NULL, NULL, NULL);) 2025.10.23 23:49:59.726785 [ 30720 ] {1ffe1ca5-e256-4fb0-b703-e90e447cf359} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) 2025.10.23 23:49:59.748401 [ 3157 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:59.917974 [ 3149 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:00.003404 [ 30720 ] {de3c62a6-b4ea-47a9-8744-b7b83a0abdee} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantiles. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT quantiles(NULL, NULL, NULL);) 2025.10.23 23:50:00.006069 [ 30720 ] {de3c62a6-b4ea-47a9-8744-b7b83a0abdee} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantiles. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:50:00.033988 [ 30720 ] {99465bca-7c85-4c26-b433-f08aedbc74d4} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesBFloat16. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT quantilesBFloat16(NULL, NULL, NULL);) 2025.10.23 23:50:00.036780 [ 30720 ] {99465bca-7c85-4c26-b433-f08aedbc74d4} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesBFloat16. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:50:00.117108 [ 30720 ] {a443a2f2-40ab-48f9-bfa0-90c0b15e7246} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesDD. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT quantilesDD(NULL, NULL, NULL);) 2025.10.23 23:50:00.120627 [ 30720 ] {a443a2f2-40ab-48f9-bfa0-90c0b15e7246} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesDD. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:50:00.151377 [ 30720 ] {9a80f089-f307-4208-81d1-e402c9fff4f9} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesDeterministic. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT quantilesDeterministic(NULL, NULL, NULL);) 2025.10.23 23:50:00.154562 [ 30720 ] {9a80f089-f307-4208-81d1-e402c9fff4f9} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesDeterministic. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:50:00.233791 [ 30720 ] {5560c66e-51c6-4913-95e4-4c1c95955705} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExact. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT quantilesExact(NULL, NULL, NULL);) 2025.10.23 23:50:00.237616 [ 30720 ] {5560c66e-51c6-4913-95e4-4c1c95955705} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExact. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:50:00.274047 [ 30720 ] {39455720-ab77-4d4a-9448-05a7992f4547} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactExclusive. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT quantilesExactExclusive(NULL, NULL, NULL);) 2025.10.23 23:50:00.279092 [ 30720 ] {39455720-ab77-4d4a-9448-05a7992f4547} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactExclusive. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:50:00.315529 [ 30720 ] {30cfbc65-524f-4f23-b883-38dc6cf0ebcf} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactHigh. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT quantilesExactHigh(NULL, NULL, NULL);) 2025.10.23 23:50:00.319477 [ 30720 ] {30cfbc65-524f-4f23-b883-38dc6cf0ebcf} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactHigh. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:50:00.425202 [ 30720 ] {b00566b3-c5fb-4a77-bcd2-fbe68edac2b5} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactInclusive. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT quantilesExactInclusive(NULL, NULL, NULL);) 2025.10.23 23:50:00.428910 [ 30720 ] {b00566b3-c5fb-4a77-bcd2-fbe68edac2b5} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactInclusive. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:50:00.459934 [ 30720 ] {806faff7-2c1e-474f-88eb-9e6df0caf1fd} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactLow. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT quantilesExactLow(NULL, NULL, NULL);) 2025.10.23 23:50:00.462318 [ 30720 ] {806faff7-2c1e-474f-88eb-9e6df0caf1fd} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactLow. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:50:00.483563 [ 30720 ] {70ac2297-4fbc-4ddc-b83b-fd85cd768152} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT quantilesExactWeighted(NULL, NULL, NULL);) 2025.10.23 23:50:00.486210 [ 30720 ] {70ac2297-4fbc-4ddc-b83b-fd85cd768152} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:50:00.508132 [ 30720 ] {6231a0cc-fc93-4d4b-a4ed-211b51ed159c} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesGK. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT quantilesGK(NULL, NULL, NULL);) 2025.10.23 23:50:00.508197 [ 3117 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:00.508246 [ 3106 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:00.510550 [ 30720 ] {6231a0cc-fc93-4d4b-a4ed-211b51ed159c} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesGK. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:50:00.558113 [ 3101 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:00.634362 [ 30720 ] {9fc81dca-e542-48c3-b847-7999406b077c} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesInterpolatedWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT quantilesInterpolatedWeighted(NULL, NULL, NULL);) 2025.10.23 23:50:00.637492 [ 30720 ] {9fc81dca-e542-48c3-b847-7999406b077c} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesInterpolatedWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:50:00.669673 [ 3097 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:00.704849 [ 30720 ] {d19422fc-4378-4577-b9e7-2768445c676f} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTDigest. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT quantilesTDigest(NULL, NULL, NULL);) 2025.10.23 23:50:00.707626 [ 30720 ] {d19422fc-4378-4577-b9e7-2768445c676f} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTDigest. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:50:00.736601 [ 30720 ] {950fe287-39fa-411a-815c-f2120cb630f6} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTDigestWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT quantilesTDigestWeighted(NULL, NULL, NULL);) 2025.10.23 23:50:00.739832 [ 30720 ] {950fe287-39fa-411a-815c-f2120cb630f6} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTDigestWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:50:00.749433 [ 3099 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:00.793480 [ 30720 ] {6835fc25-9b63-4ff7-b580-387614c8faf2} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTiming. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT quantilesTiming(NULL, NULL, NULL);) 2025.10.23 23:50:00.796352 [ 30720 ] {6835fc25-9b63-4ff7-b580-387614c8faf2} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTiming. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:50:00.819657 [ 30720 ] {b292604d-b17f-4822-8c3b-4a24039ccf00} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTimingWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT quantilesTimingWeighted(NULL, NULL, NULL);) 2025.10.23 23:50:00.822786 [ 30720 ] {b292604d-b17f-4822-8c3b-4a24039ccf00} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTimingWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:50:00.918894 [ 3091 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:00.923901 [ 30720 ] {dc469800-9fdd-4473-85a9-40b680c12dd9} executeQuery: Code: 42. DB::Exception: Number of arguments for function queryID doesn't match: passed 3, should be 0: In scope SELECT queryID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT queryID(NULL, NULL, NULL);) 2025.10.23 23:50:00.926719 [ 30720 ] {dc469800-9fdd-4473-85a9-40b680c12dd9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function queryID doesn't match: passed 3, should be 0: In scope SELECT queryID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:00.949593 [ 30720 ] {3b82cbe4-7923-4f93-9539-d043fa8cfca3} executeQuery: Code: 42. DB::Exception: Number of arguments for function queryString doesn't match: passed 3, should be 1: In scope SELECT queryString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT queryString(NULL, NULL, NULL);) 2025.10.23 23:50:00.952342 [ 30720 ] {3b82cbe4-7923-4f93-9539-d043fa8cfca3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function queryString doesn't match: passed 3, should be 1: In scope SELECT queryString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:00.973584 [ 30720 ] {7c7e2206-3fa2-4cd9-84b4-03d7701d7370} executeQuery: Code: 42. DB::Exception: Number of arguments for function queryStringAndFragment doesn't match: passed 3, should be 1: In scope SELECT queryStringAndFragment(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT queryStringAndFragment(NULL, NULL, NULL);) 2025.10.23 23:50:00.976274 [ 30720 ] {7c7e2206-3fa2-4cd9-84b4-03d7701d7370} TCPHandler: Code: 42. DB::Exception: Number of arguments for function queryStringAndFragment doesn't match: passed 3, should be 1: In scope SELECT queryStringAndFragment(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:00.999137 [ 30720 ] {4cd8ca11-578a-47c2-84b2-7bbac36af392} executeQuery: Code: 42. DB::Exception: Number of arguments for function queryID doesn't match: passed 3, should be 0: In scope SELECT query_id(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT query_id(NULL, NULL, NULL);) 2025.10.23 23:50:01.002763 [ 30720 ] {4cd8ca11-578a-47c2-84b2-7bbac36af392} TCPHandler: Code: 42. DB::Exception: Number of arguments for function queryID doesn't match: passed 3, should be 0: In scope SELECT query_id(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:01.025442 [ 30720 ] {4a8f8072-c83f-46a4-ab00-55b0cc29bdd2} executeQuery: Code: 42. DB::Exception: Number of arguments for function radians doesn't match: passed 3, should be 1: In scope SELECT radians(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT radians(NULL, NULL, NULL);) 2025.10.23 23:50:01.028456 [ 30720 ] {4a8f8072-c83f-46a4-ab00-55b0cc29bdd2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function radians doesn't match: passed 3, should be 1: In scope SELECT radians(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:01.049577 [ 30720 ] {dc0cb369-3c05-4b53-9292-de2489bcc9ef} executeQuery: Code: 42. DB::Exception: Number of arguments for function rand doesn't match: passed 3, should be 0 or 1.: In scope SELECT rand(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT rand(NULL, NULL, NULL);) 2025.10.23 23:50:01.052125 [ 30720 ] {dc0cb369-3c05-4b53-9292-de2489bcc9ef} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rand doesn't match: passed 3, should be 0 or 1.: In scope SELECT rand(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:01.073614 [ 30720 ] {6609f8dd-b26a-4946-87c8-99bd5bafcc2f} executeQuery: Code: 42. DB::Exception: Number of arguments for function rand doesn't match: passed 3, should be 0 or 1.: In scope SELECT rand32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT rand32(NULL, NULL, NULL);) 2025.10.23 23:50:01.075960 [ 30720 ] {6609f8dd-b26a-4946-87c8-99bd5bafcc2f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rand doesn't match: passed 3, should be 0 or 1.: In scope SELECT rand32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:01.095878 [ 30720 ] {b5b70d20-48b0-4ff8-b93f-d358156feb5e} executeQuery: Code: 42. DB::Exception: Number of arguments for function rand64 doesn't match: passed 3, should be 0 or 1.: In scope SELECT rand64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT rand64(NULL, NULL, NULL);) 2025.10.23 23:50:01.098410 [ 30720 ] {b5b70d20-48b0-4ff8-b93f-d358156feb5e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rand64 doesn't match: passed 3, should be 0 or 1.: In scope SELECT rand64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:01.509042 [ 3105 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:01.509277 [ 3080 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:01.553193 [ 30720 ] {a45e7096-40cb-4764-9c97-56703442516d} executeQuery: Code: 42. DB::Exception: Number of arguments for function randCanonical doesn't match: passed 3, should be 0 or 1.: In scope SELECT randCanonical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT randCanonical(NULL, NULL, NULL);) 2025.10.23 23:50:01.559455 [ 3070 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:01.650395 [ 30720 ] {a45e7096-40cb-4764-9c97-56703442516d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function randCanonical doesn't match: passed 3, should be 0 or 1.: In scope SELECT randCanonical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:01.670701 [ 3059 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:01.722749 [ 30720 ] {15619d69-424b-4af8-a112-19c640b0aa04} executeQuery: Code: 42. DB::Exception: Number of arguments for function randConstant doesn't match: passed 3, should be 0 or 1.: In scope SELECT randConstant(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT randConstant(NULL, NULL, NULL);) 2025.10.23 23:50:01.725499 [ 30720 ] {15619d69-424b-4af8-a112-19c640b0aa04} TCPHandler: Code: 42. DB::Exception: Number of arguments for function randConstant doesn't match: passed 3, should be 0 or 1.: In scope SELECT randConstant(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:01.750356 [ 3066 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:01.920105 [ 3418 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:02.382305 [ 30720 ] {1f663042-54eb-4355-97f9-89517af9db12} executeQuery: Code: 42. DB::Exception: Number of arguments for function randomFixedString doesn't match: passed 3, should be 1: In scope SELECT randomFixedString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT randomFixedString(NULL, NULL, NULL);) 2025.10.23 23:50:02.385067 [ 30720 ] {1f663042-54eb-4355-97f9-89517af9db12} TCPHandler: Code: 42. DB::Exception: Number of arguments for function randomFixedString doesn't match: passed 3, should be 1: In scope SELECT randomFixedString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:02.509742 [ 3513 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:02.510325 [ 3499 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:02.534341 [ 30720 ] {1f0de23f-dbe8-4548-abc2-b25ca5650d36} executeQuery: Code: 42. DB::Exception: Number of arguments for function randomStringUTF8 doesn't match: passed 3, should be 1: In scope SELECT randomStringUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT randomStringUTF8(NULL, NULL, NULL);) 2025.10.23 23:50:02.536942 [ 30720 ] {1f0de23f-dbe8-4548-abc2-b25ca5650d36} TCPHandler: Code: 42. DB::Exception: Number of arguments for function randomStringUTF8 doesn't match: passed 3, should be 1: In scope SELECT randomStringUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:02.560645 [ 3496 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:02.671542 [ 3476 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:02.706078 [ 30720 ] {dc2f320a-3e0f-483d-b81e-94e7ce9770e5} executeQuery: Code: 36. DB::Exception: The function 'rank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT rank(NULL, NULL, NULL);) 2025.10.23 23:50:02.710666 [ 30720 ] {dc2f320a-3e0f-483d-b81e-94e7ce9770e5} TCPHandler: Code: 36. DB::Exception: The function 'rank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.10.23 23:50:02.751105 [ 3455 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:02.786242 [ 30720 ] {48ae67a2-6ec8-4808-836d-e4116fc2ae52} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTLineString doesn't match: passed 3, should be 1: In scope SELECT readWKTLineString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT readWKTLineString(NULL, NULL, NULL);) 2025.10.23 23:50:02.788957 [ 30720 ] {48ae67a2-6ec8-4808-836d-e4116fc2ae52} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTLineString doesn't match: passed 3, should be 1: In scope SELECT readWKTLineString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:02.814902 [ 30720 ] {9773223d-d7ac-4f32-87a2-fbff0ecfc122} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTMultiLineString doesn't match: passed 3, should be 1: In scope SELECT readWKTMultiLineString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT readWKTMultiLineString(NULL, NULL, NULL);) 2025.10.23 23:50:02.817712 [ 30720 ] {9773223d-d7ac-4f32-87a2-fbff0ecfc122} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTMultiLineString doesn't match: passed 3, should be 1: In scope SELECT readWKTMultiLineString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:02.867601 [ 30720 ] {12c5b184-f359-4f97-8cc6-a1bea9a07b53} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTMultiPolygon doesn't match: passed 3, should be 1: In scope SELECT readWKTMultiPolygon(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT readWKTMultiPolygon(NULL, NULL, NULL);) 2025.10.23 23:50:02.874771 [ 30720 ] {12c5b184-f359-4f97-8cc6-a1bea9a07b53} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTMultiPolygon doesn't match: passed 3, should be 1: In scope SELECT readWKTMultiPolygon(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:02.910295 [ 30720 ] {9c33fe4a-15d9-47db-ba05-5f4e30986f41} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTPoint doesn't match: passed 3, should be 1: In scope SELECT readWKTPoint(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT readWKTPoint(NULL, NULL, NULL);) 2025.10.23 23:50:02.914263 [ 30720 ] {9c33fe4a-15d9-47db-ba05-5f4e30986f41} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTPoint doesn't match: passed 3, should be 1: In scope SELECT readWKTPoint(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:02.921444 [ 3423 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:03.020193 [ 30720 ] {1b2bb7d7-23dc-476c-abf3-5d15f828f421} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTPolygon doesn't match: passed 3, should be 1: In scope SELECT readWKTPolygon(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT readWKTPolygon(NULL, NULL, NULL);) 2025.10.23 23:50:03.024349 [ 30720 ] {1b2bb7d7-23dc-476c-abf3-5d15f828f421} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTPolygon doesn't match: passed 3, should be 1: In scope SELECT readWKTPolygon(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:03.058165 [ 30720 ] {58b0c5f9-7526-4ce3-ac45-487aaaf9d1cf} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTRing doesn't match: passed 3, should be 1: In scope SELECT readWKTRing(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT readWKTRing(NULL, NULL, NULL);) 2025.10.23 23:50:03.061972 [ 30720 ] {58b0c5f9-7526-4ce3-ac45-487aaaf9d1cf} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTRing doesn't match: passed 3, should be 1: In scope SELECT readWKTRing(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:03.193804 [ 30720 ] {bad68767-a157-4eae-806c-8e0f97bbfc1c} executeQuery: Code: 42. DB::Exception: Number of arguments for function regexpQuoteMeta doesn't match: passed 3, should be 1: In scope SELECT regexpQuoteMeta(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT regexpQuoteMeta(NULL, NULL, NULL);) 2025.10.23 23:50:03.197935 [ 30720 ] {bad68767-a157-4eae-806c-8e0f97bbfc1c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regexpQuoteMeta doesn't match: passed 3, should be 1: In scope SELECT regexpQuoteMeta(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:03.510909 [ 3361 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:03.511350 [ 3359 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:03.561723 [ 3353 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:03.672770 [ 3336 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:03.701229 [ 30720 ] {d0151a60-3a13-417d-ae0d-2c306748ef3d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=750). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT regionToName(NULL, NULL, NULL);) 2025.10.23 23:50:03.705109 [ 30720 ] {d0151a60-3a13-417d-ae0d-2c306748ef3d} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=750). (CANNOT_SCHEDULE_TASK) 2025.10.23 23:50:03.802462 [ 3328 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:03.828321 [ 30720 ] {7e3bb8df-f9cc-4c52-a94f-f3f4c79832a8} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpret doesn't match: passed 3, should be 2: In scope SELECT reinterpret(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT reinterpret(NULL, NULL, NULL);) 2025.10.23 23:50:03.832098 [ 30720 ] {7e3bb8df-f9cc-4c52-a94f-f3f4c79832a8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpret doesn't match: passed 3, should be 2: In scope SELECT reinterpret(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:03.863932 [ 30720 ] {b17240a4-2852-4b03-a577-6920b097a0d4} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsDate doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsDate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT reinterpretAsDate(NULL, NULL, NULL);) 2025.10.23 23:50:03.866700 [ 30720 ] {b17240a4-2852-4b03-a577-6920b097a0d4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsDate doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsDate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:03.922824 [ 3333 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:03.960393 [ 30720 ] {caa6ee46-3dbe-45b3-a8cb-99c0d8627f76} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsDateTime doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsDateTime(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT reinterpretAsDateTime(NULL, NULL, NULL);) 2025.10.23 23:50:03.964276 [ 30720 ] {caa6ee46-3dbe-45b3-a8cb-99c0d8627f76} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsDateTime doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsDateTime(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:03.998540 [ 3327 ] {} test_uttb102q.r1 (ReplicatedMergeTreeCleanupThread): Will mark replica 2r1 as lost, because it has stale log pointer: log-0000000000 2025.10.23 23:50:04.022159 [ 30720 ] {ed696062-8f7a-4c5c-af60-a400b2e01e05} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFixedString doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsFixedString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT reinterpretAsFixedString(NULL, NULL, NULL);) 2025.10.23 23:50:04.025909 [ 30720 ] {ed696062-8f7a-4c5c-af60-a400b2e01e05} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFixedString doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsFixedString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:04.104448 [ 30720 ] {b32a18a5-0f70-4834-91f6-b3aa5d28ea2e} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFloat32 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsFloat32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT reinterpretAsFloat32(NULL, NULL, NULL);) 2025.10.23 23:50:04.106988 [ 30720 ] {b32a18a5-0f70-4834-91f6-b3aa5d28ea2e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFloat32 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsFloat32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:04.134213 [ 30720 ] {553bcbc8-f824-4a74-9cec-d490b687429a} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFloat64 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsFloat64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT reinterpretAsFloat64(NULL, NULL, NULL);) 2025.10.23 23:50:04.136970 [ 30720 ] {553bcbc8-f824-4a74-9cec-d490b687429a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFloat64 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsFloat64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:04.240240 [ 30720 ] {f3d8d134-2ba3-4d43-8946-d6ae2c3c4886} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt128 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt128(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT reinterpretAsInt128(NULL, NULL, NULL);) 2025.10.23 23:50:04.242951 [ 30720 ] {f3d8d134-2ba3-4d43-8946-d6ae2c3c4886} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt128 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt128(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:04.273194 [ 30720 ] {a913937b-f186-45e2-9985-e53ceee0904c} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt16 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt16(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT reinterpretAsInt16(NULL, NULL, NULL);) 2025.10.23 23:50:04.275657 [ 30720 ] {a913937b-f186-45e2-9985-e53ceee0904c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt16 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt16(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:04.305842 [ 30720 ] {3583f58f-fa5e-480a-8a79-69b51fc5f71f} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt256 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt256(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT reinterpretAsInt256(NULL, NULL, NULL);) 2025.10.23 23:50:04.308585 [ 30720 ] {3583f58f-fa5e-480a-8a79-69b51fc5f71f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt256 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt256(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:04.372036 [ 30720 ] {47e4869b-3bd2-4c78-a80d-f54b85f6e0f4} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt32 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT reinterpretAsInt32(NULL, NULL, NULL);) 2025.10.23 23:50:04.424688 [ 30720 ] {47e4869b-3bd2-4c78-a80d-f54b85f6e0f4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt32 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:04.458240 [ 30720 ] {c0dc867c-af83-498c-80b9-33fccb7d7fb4} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt64 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT reinterpretAsInt64(NULL, NULL, NULL);) 2025.10.23 23:50:04.462345 [ 30720 ] {c0dc867c-af83-498c-80b9-33fccb7d7fb4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt64 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:04.496528 [ 30720 ] {e42d0148-15fd-4044-b0ea-93d3cbae77c6} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt8 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT reinterpretAsInt8(NULL, NULL, NULL);) 2025.10.23 23:50:04.512235 [ 3257 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:04.558827 [ 3270 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:04.563025 [ 3264 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:04.564553 [ 30720 ] {e42d0148-15fd-4044-b0ea-93d3cbae77c6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt8 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:04.604324 [ 30720 ] {9a1ebd64-ef1d-401b-b23d-7595cabc3613} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsString doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT reinterpretAsString(NULL, NULL, NULL);) 2025.10.23 23:50:04.608711 [ 30720 ] {9a1ebd64-ef1d-401b-b23d-7595cabc3613} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsString doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:04.673975 [ 3256 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:04.733985 [ 30720 ] {15343391-1d3f-41e9-8cea-1854a20fe4e0} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt128 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt128(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT reinterpretAsUInt128(NULL, NULL, NULL);) 2025.10.23 23:50:04.737462 [ 30720 ] {15343391-1d3f-41e9-8cea-1854a20fe4e0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt128 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt128(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:04.803542 [ 3242 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:04.860109 [ 30720 ] {086cb65a-cf58-4ca9-b808-9cd30ea86fae} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt16 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt16(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT reinterpretAsUInt16(NULL, NULL, NULL);) 2025.10.23 23:50:04.863687 [ 30720 ] {086cb65a-cf58-4ca9-b808-9cd30ea86fae} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt16 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt16(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:04.924837 [ 3228 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:04.961915 [ 30720 ] {b38f1a35-7fa7-4735-b954-2f5f34576d83} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt256 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt256(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT reinterpretAsUInt256(NULL, NULL, NULL);) 2025.10.23 23:50:04.965615 [ 30720 ] {b38f1a35-7fa7-4735-b954-2f5f34576d83} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt256 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt256(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:05.082467 [ 30720 ] {9bd4a51e-446b-4711-8d60-8ac88d8bebd1} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt32 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT reinterpretAsUInt32(NULL, NULL, NULL);) 2025.10.23 23:50:05.174263 [ 30720 ] {9bd4a51e-446b-4711-8d60-8ac88d8bebd1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt32 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:05.201341 [ 29264 ] {c92355a1-dc71-4784-bd22-ac36282d8d1e} executeQuery: Code: 591. DB::Exception: Failed to fetch table structure for '); select 1 --. (SQLITE_ENGINE_ERROR) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:35464) (comment: 01889_sqlite_read_write.sh) (in query: SELECT * FROM sqlite('/var/lib/clickhouse/user_files/test_01889_sqllite_test_1_db1', '\'); select 1 --') ORDER BY col2 -- { serverError SQLITE_ENGINE_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageSQLite.cpp:86: DB::StorageSQLite::getTableStructureFromData(std::shared_ptr const&, String const&) @ 0x0000000038b4e5ee 5. ./build_docker/./src/Storages/StorageSQLite.cpp:0: DB::StorageSQLite::StorageSQLite(DB::StorageID const&, std::shared_ptr, String const&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr) @ 0x0000000038b4d53d 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: DB::StorageSQLite* std::construct_at[abi:v15007] const&, String const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, char const (&) [1], std::shared_ptr&, DB::StorageSQLite*>(DB::StorageSQLite*, DB::StorageID&&, std::shared_ptr const&, String const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, char const (&) [1], std::shared_ptr&) @ 0x000000002feb1968 7. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID, std::shared_ptr const&, String const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, char const (&) [1], std::shared_ptr&, void>(std::allocator const&, DB::StorageID&&, std::shared_ptr const&, String const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, char const (&) [1], std::shared_ptr&) @ 0x000000002feb12d4 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::(anonymous namespace)::TableFunctionSQLite::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002feb0cb0 9. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f70b3 10. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000003374cff2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4838: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003345fff3 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334edd21 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436960 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 31. ? @ 0x00007f100c857ac3 2025.10.23 23:50:05.204178 [ 29264 ] {c92355a1-dc71-4784-bd22-ac36282d8d1e} TCPHandler: Code: 591. DB::Exception: Failed to fetch table structure for '); select 1 --. (SQLITE_ENGINE_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageSQLite.cpp:86: DB::StorageSQLite::getTableStructureFromData(std::shared_ptr const&, String const&) @ 0x0000000038b4e5ee 5. ./build_docker/./src/Storages/StorageSQLite.cpp:0: DB::StorageSQLite::StorageSQLite(DB::StorageID const&, std::shared_ptr, String const&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr) @ 0x0000000038b4d53d 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: DB::StorageSQLite* std::construct_at[abi:v15007] const&, String const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, char const (&) [1], std::shared_ptr&, DB::StorageSQLite*>(DB::StorageSQLite*, DB::StorageID&&, std::shared_ptr const&, String const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, char const (&) [1], std::shared_ptr&) @ 0x000000002feb1968 7. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID, std::shared_ptr const&, String const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, char const (&) [1], std::shared_ptr&, void>(std::allocator const&, DB::StorageID&&, std::shared_ptr const&, String const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, char const (&) [1], std::shared_ptr&) @ 0x000000002feb12d4 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::(anonymous namespace)::TableFunctionSQLite::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002feb0cb0 9. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f70b3 10. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000003374cff2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4838: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003345fff3 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334edd21 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436960 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 31. ? @ 0x00007f100c857ac3 2025.10.23 23:50:05.288963 [ 30720 ] {1d45b75a-ba74-44bd-9cf1-b8ecc0f82a40} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt64 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT reinterpretAsUInt64(NULL, NULL, NULL);) 2025.10.23 23:50:05.293020 [ 30720 ] {1d45b75a-ba74-44bd-9cf1-b8ecc0f82a40} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt64 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:05.326368 [ 30720 ] {839846e8-21a2-49b1-a900-e8ec545645f7} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt8 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT reinterpretAsUInt8(NULL, NULL, NULL);) 2025.10.23 23:50:05.337892 [ 30720 ] {839846e8-21a2-49b1-a900-e8ec545645f7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt8 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:05.366066 [ 30720 ] {ef12c1ae-03bf-4d2e-903f-faf42d5df980} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUUID doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUUID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT reinterpretAsUUID(NULL, NULL, NULL);) 2025.10.23 23:50:05.369917 [ 30720 ] {ef12c1ae-03bf-4d2e-903f-faf42d5df980} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUUID doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUUID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:05.460970 [ 30720 ] {b673e25f-235f-46b1-9be8-f810b24db3b1} executeQuery: Code: 42. DB::Exception: Number of arguments for function repeat doesn't match: passed 3, should be 2: In scope SELECT repeat(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT repeat(NULL, NULL, NULL);) 2025.10.23 23:50:05.463322 [ 30720 ] {b673e25f-235f-46b1-9be8-f810b24db3b1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function repeat doesn't match: passed 3, should be 2: In scope SELECT repeat(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:05.513080 [ 3180 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:05.559571 [ 3179 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:05.628537 [ 3173 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:05.674994 [ 3166 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:05.792485 [ 30720 ] {ba3cd69e-be1c-4c6b-acf5-bca71ef51005} executeQuery: Code: 43. DB::Exception: Argument 2 for function replicate must be array.: In scope SELECT replicate(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT replicate(NULL, NULL, NULL);) 2025.10.23 23:50:05.794894 [ 30720 ] {ba3cd69e-be1c-4c6b-acf5-bca71ef51005} TCPHandler: Code: 43. DB::Exception: Argument 2 for function replicate must be array.: In scope SELECT replicate(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:50:05.804788 [ 3139 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:05.811327 [ 29264 ] {8f188239-8e14-438e-b15b-113697bd7888} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:57688) (comment: 01889_sqlite_read_write.sh) (in query: SELECT * FROM sqlite('/var/lib/clickhouse/user_files/test_01889_sqllite_test_1_db1', 'table6''') ORDER BY col2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:50:05.817913 [ 29264 ] {8f188239-8e14-438e-b15b-113697bd7888} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:50:05.926130 [ 3149 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:06.015662 [ 30720 ] {0a3b6843-ab8d-4e4e-8d54-047d29b1ff43} executeQuery: Code: 42. DB::Exception: Number of arguments for function reverse doesn't match: passed 3, should be 1: In scope SELECT reverse(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT reverse(NULL, NULL, NULL);) 2025.10.23 23:50:06.107368 [ 30720 ] {0a3b6843-ab8d-4e4e-8d54-047d29b1ff43} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reverse doesn't match: passed 3, should be 1: In scope SELECT reverse(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:06.139647 [ 30720 ] {550b0c76-05f3-455f-9d01-1911fe9c332b} executeQuery: Code: 42. DB::Exception: Number of arguments for function reverseUTF8 doesn't match: passed 3, should be 1: In scope SELECT reverseUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT reverseUTF8(NULL, NULL, NULL);) 2025.10.23 23:50:06.142870 [ 30720 ] {550b0c76-05f3-455f-9d01-1911fe9c332b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reverseUTF8 doesn't match: passed 3, should be 1: In scope SELECT reverseUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:06.169022 [ 30720 ] {f3e96928-6a66-404a-b79f-b3617e744994} executeQuery: Code: 42. DB::Exception: Number of arguments for function revision doesn't match: passed 3, should be 0: In scope SELECT revision(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT revision(NULL, NULL, NULL);) 2025.10.23 23:50:06.171806 [ 30720 ] {f3e96928-6a66-404a-b79f-b3617e744994} TCPHandler: Code: 42. DB::Exception: Number of arguments for function revision doesn't match: passed 3, should be 0: In scope SELECT revision(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:06.197291 [ 30720 ] {c336f734-2640-4bcf-9f9e-ea20f206a404} executeQuery: Code: 42. DB::Exception: Number of arguments for function right doesn't match: passed 3, should be 2: In scope SELECT right(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT right(NULL, NULL, NULL);) 2025.10.23 23:50:06.199927 [ 30720 ] {c336f734-2640-4bcf-9f9e-ea20f206a404} TCPHandler: Code: 42. DB::Exception: Number of arguments for function right doesn't match: passed 3, should be 2: In scope SELECT right(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:06.375166 [ 30720 ] {79d66956-61c7-4a3f-90f7-dac48663c295} executeQuery: Code: 42. DB::Exception: Number of arguments for function rightUTF8 doesn't match: passed 3, should be 2: In scope SELECT rightUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT rightUTF8(NULL, NULL, NULL);) 2025.10.23 23:50:06.377851 [ 30720 ] {79d66956-61c7-4a3f-90f7-dac48663c295} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rightUTF8 doesn't match: passed 3, should be 2: In scope SELECT rightUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:06.437817 [ 30720 ] {b6c8d668-da87-47eb-8633-b6b1d50c133f} executeQuery: Code: 42. DB::Exception: Number of arguments for function roundAge doesn't match: passed 3, should be 1: In scope SELECT roundAge(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT roundAge(NULL, NULL, NULL);) 2025.10.23 23:50:06.440593 [ 30720 ] {b6c8d668-da87-47eb-8633-b6b1d50c133f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function roundAge doesn't match: passed 3, should be 1: In scope SELECT roundAge(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:06.502199 [ 30720 ] {8ef5f641-2492-4a74-8319-c948376cf468} executeQuery: Code: 42. DB::Exception: Number of arguments for function roundDown doesn't match: passed 3, should be 2: In scope SELECT roundDown(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT roundDown(NULL, NULL, NULL);) 2025.10.23 23:50:06.504896 [ 30720 ] {8ef5f641-2492-4a74-8319-c948376cf468} TCPHandler: Code: 42. DB::Exception: Number of arguments for function roundDown doesn't match: passed 3, should be 2: In scope SELECT roundDown(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:06.513866 [ 3124 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:06.527681 [ 30720 ] {4b49f555-b062-4388-86d6-2ec808fcc358} executeQuery: Code: 42. DB::Exception: Number of arguments for function roundDuration doesn't match: passed 3, should be 1: In scope SELECT roundDuration(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT roundDuration(NULL, NULL, NULL);) 2025.10.23 23:50:06.530295 [ 30720 ] {4b49f555-b062-4388-86d6-2ec808fcc358} TCPHandler: Code: 42. DB::Exception: Number of arguments for function roundDuration doesn't match: passed 3, should be 1: In scope SELECT roundDuration(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:06.560577 [ 3174 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:06.585403 [ 30720 ] {4a3a9429-eabb-4383-966b-8f55eea01992} executeQuery: Code: 42. DB::Exception: Number of arguments for function roundToExp2 doesn't match: passed 3, should be 1: In scope SELECT roundToExp2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT roundToExp2(NULL, NULL, NULL);) 2025.10.23 23:50:06.627171 [ 30720 ] {4a3a9429-eabb-4383-966b-8f55eea01992} TCPHandler: Code: 42. DB::Exception: Number of arguments for function roundToExp2 doesn't match: passed 3, should be 1: In scope SELECT roundToExp2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:06.629676 [ 3562 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:06.658498 [ 30720 ] {0a4b1d53-fac9-49c0-818a-50230cbde91b} executeQuery: Code: 42. DB::Exception: Number of arguments for function rowNumberInAllBlocks doesn't match: passed 3, should be 0: In scope SELECT rowNumberInAllBlocks(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT rowNumberInAllBlocks(NULL, NULL, NULL);) 2025.10.23 23:50:06.675846 [ 3550 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:06.759157 [ 30720 ] {0a4b1d53-fac9-49c0-818a-50230cbde91b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rowNumberInAllBlocks doesn't match: passed 3, should be 0: In scope SELECT rowNumberInAllBlocks(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:06.783650 [ 30720 ] {0997a80d-8e6c-4f2e-87db-970baac334cf} executeQuery: Code: 42. DB::Exception: Number of arguments for function rowNumberInBlock doesn't match: passed 3, should be 0: In scope SELECT rowNumberInBlock(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT rowNumberInBlock(NULL, NULL, NULL);) 2025.10.23 23:50:06.786297 [ 30720 ] {0997a80d-8e6c-4f2e-87db-970baac334cf} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rowNumberInBlock doesn't match: passed 3, should be 0: In scope SELECT rowNumberInBlock(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:06.805816 [ 3543 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:06.830263 [ 30720 ] {c44f599a-b1bb-445c-8941-7d9f61fa3c80} executeQuery: Code: 36. DB::Exception: The function 'row_number' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT row_number(NULL, NULL, NULL);) 2025.10.23 23:50:06.835153 [ 30720 ] {c44f599a-b1bb-445c-8941-7d9f61fa3c80} TCPHandler: Code: 36. DB::Exception: The function 'row_number' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.10.23 23:50:06.927081 [ 3530 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:07.300846 [ 30720 ] {eb6bdca8-530f-4458-8fa4-ab32b46e5aa1} executeQuery: Code: 721. DB::Exception: Function runningAccumulate is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT runningAccumulate(NULL, NULL, NULL);) 2025.10.23 23:50:07.304655 [ 30720 ] {eb6bdca8-530f-4458-8fa4-ab32b46e5aa1} TCPHandler: Code: 721. DB::Exception: Function runningAccumulate is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) 2025.10.23 23:50:07.349529 [ 30720 ] {db92d370-bb3b-499c-879c-8aeda1e562d9} executeQuery: Code: 42. DB::Exception: Number of arguments for function runningConcurrency doesn't match: passed 3, should be 2: In scope SELECT runningConcurrency(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT runningConcurrency(NULL, NULL, NULL);) 2025.10.23 23:50:07.352846 [ 30720 ] {db92d370-bb3b-499c-879c-8aeda1e562d9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function runningConcurrency doesn't match: passed 3, should be 2: In scope SELECT runningConcurrency(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:07.373573 [ 30720 ] {dd5305fe-d9c3-4c07-be1b-602df0352b40} executeQuery: Code: 721. DB::Exception: Function runningDifference is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT runningDifference(NULL, NULL, NULL);) 2025.10.23 23:50:07.376045 [ 30720 ] {dd5305fe-d9c3-4c07-be1b-602df0352b40} TCPHandler: Code: 721. DB::Exception: Function runningDifference is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) 2025.10.23 23:50:07.396199 [ 30720 ] {7614dab2-7a23-487a-90c6-58f880d290bb} executeQuery: Code: 721. DB::Exception: Function runningDifferenceStartingWithFirstValue is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT runningDifferenceStartingWithFirstValue(NULL, NULL, NULL);) 2025.10.23 23:50:07.398486 [ 30720 ] {7614dab2-7a23-487a-90c6-58f880d290bb} TCPHandler: Code: 721. DB::Exception: Function runningDifferenceStartingWithFirstValue is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) 2025.10.23 23:50:07.454580 [ 30720 ] {426b1b25-27e2-4618-a284-af7b5b1f8770} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2CapUnion doesn't match: passed 3, should be 4: In scope SELECT s2CapUnion(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT s2CapUnion(NULL, NULL, NULL);) 2025.10.23 23:50:07.456871 [ 30720 ] {426b1b25-27e2-4618-a284-af7b5b1f8770} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2CapUnion doesn't match: passed 3, should be 4: In scope SELECT s2CapUnion(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:07.515056 [ 3477 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:07.561454 [ 3490 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:07.609613 [ 30720 ] {64c5997b-3e4f-4403-859f-fc745b3a9c26} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2CellsIntersect doesn't match: passed 3, should be 2: In scope SELECT s2CellsIntersect(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT s2CellsIntersect(NULL, NULL, NULL);) 2025.10.23 23:50:07.614069 [ 30720 ] {64c5997b-3e4f-4403-859f-fc745b3a9c26} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2CellsIntersect doesn't match: passed 3, should be 2: In scope SELECT s2CellsIntersect(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:07.630747 [ 3461 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:07.637326 [ 30720 ] {1efe24b1-5f07-4005-bc38-5850afb11fc9} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2GetNeighbors doesn't match: passed 3, should be 1: In scope SELECT s2GetNeighbors(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT s2GetNeighbors(NULL, NULL, NULL);) 2025.10.23 23:50:07.639839 [ 30720 ] {1efe24b1-5f07-4005-bc38-5850afb11fc9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2GetNeighbors doesn't match: passed 3, should be 1: In scope SELECT s2GetNeighbors(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:07.676719 [ 3459 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:07.791775 [ 30720 ] {09423c30-f909-4fa4-a26d-80236ad7b3b1} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2RectIntersection doesn't match: passed 3, should be 4: In scope SELECT s2RectIntersection(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT s2RectIntersection(NULL, NULL, NULL);) 2025.10.23 23:50:07.806671 [ 3423 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:07.820298 [ 30720 ] {09423c30-f909-4fa4-a26d-80236ad7b3b1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2RectIntersection doesn't match: passed 3, should be 4: In scope SELECT s2RectIntersection(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:07.842405 [ 30720 ] {32cd010f-403d-4b31-a42f-02e5a58c6eed} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2RectUnion doesn't match: passed 3, should be 4: In scope SELECT s2RectUnion(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT s2RectUnion(NULL, NULL, NULL);) 2025.10.23 23:50:07.863574 [ 30720 ] {32cd010f-403d-4b31-a42f-02e5a58c6eed} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2RectUnion doesn't match: passed 3, should be 4: In scope SELECT s2RectUnion(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:07.887279 [ 30720 ] {4e5236d7-6e4e-414b-9815-1500ae9e37ff} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2ToGeo doesn't match: passed 3, should be 1: In scope SELECT s2ToGeo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT s2ToGeo(NULL, NULL, NULL);) 2025.10.23 23:50:07.889721 [ 30720 ] {4e5236d7-6e4e-414b-9815-1500ae9e37ff} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2ToGeo doesn't match: passed 3, should be 1: In scope SELECT s2ToGeo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:07.911942 [ 30720 ] {99b6bab7-01be-4919-a6d9-b0472d235f39} executeQuery: Code: 42. DB::Exception: Number of arguments for function dotProduct doesn't match: passed 3, should be 2: In scope SELECT scalarProduct(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT scalarProduct(NULL, NULL, NULL);) 2025.10.23 23:50:07.914789 [ 30720 ] {99b6bab7-01be-4919-a6d9-b0472d235f39} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dotProduct doesn't match: passed 3, should be 2: In scope SELECT scalarProduct(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:07.977845 [ 3378 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:08.086073 [ 3361 ] {} test_1.quorum1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.10.23 23:50:08.086263 [ 3358 ] {} test_1.wrong_metadata (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.10.23 23:50:08.086315 [ 3363 ] {} test_uttb102q.r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.10.23 23:50:08.086500 [ 3357 ] {} test_1.wrong_metadata_compact (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.10.23 23:50:08.086811 [ 3353 ] {} test_1.`.inner_id.bf35c401-0f19-4b9c-80da-ff988095e143` (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.10.23 23:50:08.086896 [ 3346 ] {} test_15.r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.10.23 23:50:08.087493 [ 3336 ] {} test_1.`.inner_id.bf35c401-0f19-4b9c-80da-ff988095e143` (a61f0b50-5b9e-495d-84b6-90e5eb7bcca5): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/03143_parallel_replicas_mat_view_bug/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:08.087506 [ 3339 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/02725_start_stop_fetches_test_15/r/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:08.087918 [ 3343 ] {} test_uttb102q.r1 (838ef953-9861-4962-9055-934d1b64d4f5): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000003cc8de51 3. ./src/Common/ZooKeeper/IKeeper.h:509: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003cd16a3e 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003cd2369f 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe6e6d 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe5f26 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe84e7 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe81ea 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000003a10064e 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000003889f11d 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f9f 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:08.088022 [ 30720 ] {c4b3a3e3-91d9-435e-9c0e-849234201311} executeQuery: Code: 63. DB::Exception: Aggregate function sequenceNextNode is experimental. Set `allow_experimental_funnel_functions` setting to enable it. (UNKNOWN_AGGREGATE_FUNCTION) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT sequenceNextNode(NULL, NULL, NULL);) 2025.10.23 23:50:08.088052 [ 3349 ] {} test_1.`.inner_id.bf35c401-0f19-4b9c-80da-ff988095e143` (a61f0b50-5b9e-495d-84b6-90e5eb7bcca5): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000003cc8de51 3. ./src/Common/ZooKeeper/IKeeper.h:509: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003cd16a3e 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003cd2369f 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe6e6d 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe5f26 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe84e7 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe81ea 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000003a10064e 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000003889f11d 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f9f 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:08.088433 [ 3344 ] {} test_15.r2 (1d1e26e6-ff94-4ce0-9b88-d0e0eed8b59c): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000003cc8de51 3. ./src/Common/ZooKeeper/IKeeper.h:509: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003cd16a3e 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003cd2369f 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe6e6d 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe5f26 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe84e7 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cbe81ea 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000003a10064e 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000003889f11d 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f9f 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:08.093404 [ 30720 ] {c4b3a3e3-91d9-435e-9c0e-849234201311} TCPHandler: Code: 63. DB::Exception: Aggregate function sequenceNextNode is experimental. Set `allow_experimental_funnel_functions` setting to enable it. (UNKNOWN_AGGREGATE_FUNCTION) 2025.10.23 23:50:08.114584 [ 30720 ] {09b8a503-bddd-4048-8237-75642964df23} executeQuery: Code: 42. DB::Exception: Number of arguments for function seriesDecomposeSTL doesn't match: passed 3, should be 2: In scope SELECT seriesDecomposeSTL(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT seriesDecomposeSTL(NULL, NULL, NULL);) 2025.10.23 23:50:08.117377 [ 30720 ] {09b8a503-bddd-4048-8237-75642964df23} TCPHandler: Code: 42. DB::Exception: Number of arguments for function seriesDecomposeSTL doesn't match: passed 3, should be 2: In scope SELECT seriesDecomposeSTL(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:08.243103 [ 30720 ] {5e7a084c-feff-4cbb-ac31-17e1c028be30} executeQuery: Code: 42. DB::Exception: Number of arguments for function seriesPeriodDetectFFT doesn't match: passed 3, should be 1: In scope SELECT seriesPeriodDetectFFT(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT seriesPeriodDetectFFT(NULL, NULL, NULL);) 2025.10.23 23:50:08.245635 [ 30720 ] {5e7a084c-feff-4cbb-ac31-17e1c028be30} TCPHandler: Code: 42. DB::Exception: Number of arguments for function seriesPeriodDetectFFT doesn't match: passed 3, should be 1: In scope SELECT seriesPeriodDetectFFT(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:08.320028 [ 30720 ] {9dcffbee-5858-443f-8a16-092a32079450} executeQuery: Code: 42. DB::Exception: Number of arguments for function serverTimezone doesn't match: passed 3, should be 0: In scope SELECT serverTimeZone(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT serverTimeZone(NULL, NULL, NULL);) 2025.10.23 23:50:08.322464 [ 30720 ] {9dcffbee-5858-443f-8a16-092a32079450} TCPHandler: Code: 42. DB::Exception: Number of arguments for function serverTimezone doesn't match: passed 3, should be 0: In scope SELECT serverTimeZone(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:08.342510 [ 30720 ] {008b0bcf-ed52-4d42-a3ae-cddeb173524e} executeQuery: Code: 42. DB::Exception: Number of arguments for function serverTimezone doesn't match: passed 3, should be 0: In scope SELECT serverTimezone(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT serverTimezone(NULL, NULL, NULL);) 2025.10.23 23:50:08.345023 [ 30720 ] {008b0bcf-ed52-4d42-a3ae-cddeb173524e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function serverTimezone doesn't match: passed 3, should be 0: In scope SELECT serverTimezone(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:08.474777 [ 30720 ] {efebe390-fbe3-4792-a43c-f88df521573e} executeQuery: Code: 42. DB::Exception: Number of arguments for function serverUUID doesn't match: passed 3, should be 0: In scope SELECT serverUUID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT serverUUID(NULL, NULL, NULL);) 2025.10.23 23:50:08.498177 [ 30720 ] {efebe390-fbe3-4792-a43c-f88df521573e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function serverUUID doesn't match: passed 3, should be 0: In scope SELECT serverUUID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:08.516311 [ 3302 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:08.519438 [ 30720 ] {432f2743-3027-4ad8-b2f3-e32a8aed2945} executeQuery: Code: 42. DB::Exception: Number of arguments for function shardCount doesn't match: passed 3, should be 0: In scope SELECT shardCount(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT shardCount(NULL, NULL, NULL);) 2025.10.23 23:50:08.521945 [ 30720 ] {432f2743-3027-4ad8-b2f3-e32a8aed2945} TCPHandler: Code: 42. DB::Exception: Number of arguments for function shardCount doesn't match: passed 3, should be 0: In scope SELECT shardCount(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:08.542707 [ 30720 ] {af35a44d-e759-4cd8-a32e-98a5bc35df98} executeQuery: Code: 42. DB::Exception: Number of arguments for function shardNum doesn't match: passed 3, should be 0: In scope SELECT shardNum(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT shardNum(NULL, NULL, NULL);) 2025.10.23 23:50:08.562152 [ 3293 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:08.575307 [ 30720 ] {af35a44d-e759-4cd8-a32e-98a5bc35df98} TCPHandler: Code: 42. DB::Exception: Number of arguments for function shardNum doesn't match: passed 3, should be 0: In scope SELECT shardNum(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:08.601075 [ 30720 ] {bbe2dc29-e8cf-48c1-a96a-b8f5a7ba40d0} executeQuery: Code: 42. DB::Exception: Number of arguments for function showCertificate doesn't match: passed 3, should be 0: In scope SELECT showCertificate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT showCertificate(NULL, NULL, NULL);) 2025.10.23 23:50:08.603426 [ 30720 ] {bbe2dc29-e8cf-48c1-a96a-b8f5a7ba40d0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function showCertificate doesn't match: passed 3, should be 0: In scope SELECT showCertificate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:08.627252 [ 30720 ] {545b4ba2-cc4a-4a9e-acd6-9a95b4909eee} executeQuery: Code: 42. DB::Exception: Number of arguments for function sigmoid doesn't match: passed 3, should be 1: In scope SELECT sigmoid(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT sigmoid(NULL, NULL, NULL);) 2025.10.23 23:50:08.629558 [ 30720 ] {545b4ba2-cc4a-4a9e-acd6-9a95b4909eee} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sigmoid doesn't match: passed 3, should be 1: In scope SELECT sigmoid(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:08.651351 [ 30720 ] {3749613a-0918-4631-92b8-69f6be71a32e} executeQuery: Code: 42. DB::Exception: Number of arguments for function sign doesn't match: passed 3, should be 1: In scope SELECT sign(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT sign(NULL, NULL, NULL);) 2025.10.23 23:50:08.653668 [ 30720 ] {3749613a-0918-4631-92b8-69f6be71a32e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sign doesn't match: passed 3, should be 1: In scope SELECT sign(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:08.657739 [ 3288 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:08.677548 [ 3289 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:08.733393 [ 30720 ] {fc29fa38-feb6-4606-ba8c-ed185718b0cf} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractBool doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractBool(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT simpleJSONExtractBool(NULL, NULL, NULL);) 2025.10.23 23:50:08.797619 [ 30720 ] {fc29fa38-feb6-4606-ba8c-ed185718b0cf} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractBool doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractBool(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:08.816880 [ 3285 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:08.820299 [ 30720 ] {7d317d6b-d6d9-4c75-bc66-7e76d48ba7e1} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractFloat doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractFloat(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT simpleJSONExtractFloat(NULL, NULL, NULL);) 2025.10.23 23:50:08.822770 [ 30720 ] {7d317d6b-d6d9-4c75-bc66-7e76d48ba7e1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractFloat doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractFloat(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:08.846645 [ 30720 ] {de2d233e-c4f0-4203-ba63-78132cd177b2} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractInt doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractInt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT simpleJSONExtractInt(NULL, NULL, NULL);) 2025.10.23 23:50:08.849174 [ 30720 ] {de2d233e-c4f0-4203-ba63-78132cd177b2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractInt doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractInt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:08.892102 [ 30720 ] {615e36f4-5fa6-4b6b-a70a-0711aa213e58} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractRaw doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractRaw(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT simpleJSONExtractRaw(NULL, NULL, NULL);) 2025.10.23 23:50:08.894444 [ 30720 ] {615e36f4-5fa6-4b6b-a70a-0711aa213e58} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractRaw doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractRaw(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:08.978702 [ 3280 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:09.009045 [ 30720 ] {6a1bdd1c-361b-4027-bc58-4e6735c49f2b} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractString doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT simpleJSONExtractString(NULL, NULL, NULL);) 2025.10.23 23:50:09.011522 [ 30720 ] {6a1bdd1c-361b-4027-bc58-4e6735c49f2b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractString doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:09.036021 [ 30720 ] {a3fc96a2-987d-440b-9a6a-43eebafcaa24} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractUInt doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractUInt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT simpleJSONExtractUInt(NULL, NULL, NULL);) 2025.10.23 23:50:09.038360 [ 30720 ] {a3fc96a2-987d-440b-9a6a-43eebafcaa24} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractUInt doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractUInt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:09.157142 [ 30720 ] {7583cc7c-aac7-48e0-bd01-d857e9b7ebaf} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONHas doesn't match: passed 3, should be 2: In scope SELECT simpleJSONHas(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT simpleJSONHas(NULL, NULL, NULL);) 2025.10.23 23:50:09.159947 [ 30720 ] {7583cc7c-aac7-48e0-bd01-d857e9b7ebaf} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONHas doesn't match: passed 3, should be 2: In scope SELECT simpleJSONHas(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:09.207409 [ 30720 ] {fdbf9990-9fbe-471f-bdcc-63237568b524} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT simpleLinearRegression(NULL, NULL, NULL);) 2025.10.23 23:50:09.211419 [ 30720 ] {fdbf9990-9fbe-471f-bdcc-63237568b524} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) 2025.10.23 23:50:09.237742 [ 30720 ] {6256b6b6-490e-4655-b5e9-85e79303c76c} executeQuery: Code: 42. DB::Exception: Number of arguments for function sin doesn't match: passed 3, should be 1: In scope SELECT sin(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT sin(NULL, NULL, NULL);) 2025.10.23 23:50:09.240995 [ 30720 ] {6256b6b6-490e-4655-b5e9-85e79303c76c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sin doesn't match: passed 3, should be 1: In scope SELECT sin(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:09.318339 [ 30720 ] {6dfc4a2b-b024-43a3-b831-069f810eb87d} executeQuery: Code: 42. DB::Exception: Number of arguments for function sinh doesn't match: passed 3, should be 1: In scope SELECT sinh(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT sinh(NULL, NULL, NULL);) 2025.10.23 23:50:09.320805 [ 30720 ] {6dfc4a2b-b024-43a3-b831-069f810eb87d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sinh doesn't match: passed 3, should be 1: In scope SELECT sinh(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:09.477674 [ 2903 ] {db18a72a-eb55-4e60-884b-10bb770f05c2} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage SQLite. (NOT_IMPLEMENTED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:57764) (comment: 01889_sqlite_read_write.sh) (in query: DROP TABLE sqlite_table3_inferred_engine;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000002ffc5e67 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003493f2d5 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:50:09.480194 [ 2903 ] {db18a72a-eb55-4e60-884b-10bb770f05c2} TCPHandler: Code: 48. DB::Exception: Truncate is not supported by storage SQLite. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000002ffc5e67 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003493f2d5 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:50:09.517300 [ 3268 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:09.562936 [ 3257 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:09.659032 [ 3261 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:09.678356 [ 3274 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:09.817830 [ 3260 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:09.909026 [ 30720 ] {4ebc825e-4f9e-485e-b5e5-7778bbcd13d0} executeQuery: Code: 42. DB::Exception: Number of arguments for function sleep doesn't match: passed 3, should be 1: In scope SELECT sleep(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT sleep(NULL, NULL, NULL);) 2025.10.23 23:50:09.913482 [ 30720 ] {4ebc825e-4f9e-485e-b5e5-7778bbcd13d0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sleep doesn't match: passed 3, should be 1: In scope SELECT sleep(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:09.940410 [ 30720 ] {a35366c1-38b0-42c9-b257-07e272d237c0} executeQuery: Code: 42. DB::Exception: Number of arguments for function sleepEachRow doesn't match: passed 3, should be 1: In scope SELECT sleepEachRow(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT sleepEachRow(NULL, NULL, NULL);) 2025.10.23 23:50:09.944237 [ 30720 ] {a35366c1-38b0-42c9-b257-07e272d237c0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sleepEachRow doesn't match: passed 3, should be 1: In scope SELECT sleepEachRow(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:09.980064 [ 3271 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:10.244391 [ 3362 ] {} test_uttb102q.r1 (838ef953-9861-4962-9055-934d1b64d4f5): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 999. Coordination::Exception: Session expired (fault injected on send). (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000003a21d8b1 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEES0_NS_5ErrorEOS5_ @ 0x000000003cd2cd64 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1654: Coordination::ZooKeeper::maybeInjectSendFault() @ 0x000000003cd17122 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003cd165e8 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1515: Coordination::ZooKeeper::multi(std::span const, 18446744073709551615ul>, std::function) @ 0x000000003cd2826c 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryMultiNoThrow(std::span const, 18446744073709551615ul>) @ 0x000000003cc1d586 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::multiImpl(std::vector, std::allocator>> const&, std::vector, std::allocator>>&, bool) @ 0x000000003cbedff9 9. ./contrib/llvm-project/libcxx/include/string:1499: zkutil::ZooKeeper::multi(std::vector, std::allocator>> const&, bool) @ 0x000000003cbfa26b 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:0: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x000000003a0f850e 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003889e7df 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 15. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:10.246020 [ 3362 ] {} test_uttb102q.r1 (838ef953-9861-4962-9055-934d1b64d4f5): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01396_inactive_replica_cleanup_nodes_zookeeper_test_uttb102q/s1/replicas/1r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:10.441275 [ 30720 ] {fb6973fa-2f73-448e-93bd-445f04a56ec8} executeQuery: Code: 42. DB::Exception: Number of arguments for function soundex doesn't match: passed 3, should be 1: In scope SELECT soundex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT soundex(NULL, NULL, NULL);) 2025.10.23 23:50:10.443378 [ 4841 ] {f43e8f5c-f532-4b65-9a61-b8d3b114fc86} executeQuery: Code: 242. DB::Exception: Table is in readonly mode: replica_path=/clickhouse/tables/01396_inactive_replica_cleanup_nodes_zookeeper_test_uttb102q/s1/replicas/1r1. (TABLE_IS_READ_ONLY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:35438) (comment: 01396_inactive_replica_cleanup_nodes_zookeeper.sh) (in query: INSERT INTO r1 SELECT * FROM numbers_mt(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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000003a2406e5 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000003a23f9db 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()::operator()() const @ 0x000000003a23f659 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000003a23f05f 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1133: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x000000003a209ab0 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:463: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x000000003a1dcdb4 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:408: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a20285e 10. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bb51384 11. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b82a9a9 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b82a4b6 13. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b829167 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 18. ./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*) @ 0x000000003aea17d9 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 21. ? @ 0x00007f100c857ac3 22. ? @ 0x00007f100c8e9850 2025.10.23 23:50:10.443599 [ 30720 ] {fb6973fa-2f73-448e-93bd-445f04a56ec8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function soundex doesn't match: passed 3, should be 1: In scope SELECT soundex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:10.463389 [ 30720 ] {533214a6-15d6-45a7-a4dd-b6e49f7f895b} executeQuery: Code: 42. DB::Exception: Number of arguments for function space doesn't match: passed 3, should be 1: In scope SELECT space(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT space(NULL, NULL, NULL);) 2025.10.23 23:50:10.466130 [ 30720 ] {533214a6-15d6-45a7-a4dd-b6e49f7f895b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function space doesn't match: passed 3, should be 1: In scope SELECT space(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:10.507826 [ 4841 ] {f43e8f5c-f532-4b65-9a61-b8d3b114fc86} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode: replica_path=/clickhouse/tables/01396_inactive_replica_cleanup_nodes_zookeeper_test_uttb102q/s1/replicas/1r1. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000003a2406e5 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000003a23f9db 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()::operator()() const @ 0x000000003a23f659 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000003a23f05f 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1133: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x000000003a209ab0 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:463: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x000000003a1dcdb4 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:408: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a20285e 10. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bb51384 11. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b82a9a9 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b82a4b6 13. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b829167 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 18. ./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*) @ 0x000000003aea17d9 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 21. ? @ 0x00007f100c857ac3 22. ? @ 0x00007f100c8e9850 2025.10.23 23:50:10.518019 [ 3556 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:10.563898 [ 3540 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:10.660369 [ 3565 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:10.679224 [ 3552 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:10.818878 [ 3527 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:10.981074 [ 3543 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:11.183612 [ 30720 ] {7ddc2518-3ae4-4bd8-a254-adb583646bb3} executeQuery: Code: 42. DB::Exception: Number of arguments for function sqidDecode doesn't match: passed 3, should be 1: In scope SELECT sqidDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT sqidDecode(NULL, NULL, NULL);) 2025.10.23 23:50:11.186601 [ 30720 ] {7ddc2518-3ae4-4bd8-a254-adb583646bb3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sqidDecode doesn't match: passed 3, should be 1: In scope SELECT sqidDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:11.245082 [ 30720 ] {70c3477e-69dc-402b-98e9-6cb6f9d1c9f8} executeQuery: Code: 42. DB::Exception: Number of arguments for function sqrt doesn't match: passed 3, should be 1: In scope SELECT sqrt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT sqrt(NULL, NULL, NULL);) 2025.10.23 23:50:11.247630 [ 30720 ] {70c3477e-69dc-402b-98e9-6cb6f9d1c9f8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sqrt doesn't match: passed 3, should be 1: In scope SELECT sqrt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:11.322722 [ 30720 ] {60559bdf-6e08-4c68-a04c-8ac71eecf286} executeQuery: Code: 42. DB::Exception: Number of arguments for function startsWith doesn't match: passed 3, should be 2: In scope SELECT startsWith(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT startsWith(NULL, NULL, NULL);) 2025.10.23 23:50:11.325444 [ 30720 ] {60559bdf-6e08-4c68-a04c-8ac71eecf286} TCPHandler: Code: 42. DB::Exception: Number of arguments for function startsWith doesn't match: passed 3, should be 2: In scope SELECT startsWith(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:11.351929 [ 30720 ] {7f8328e3-4c50-4cdc-83a8-5ce3da797365} executeQuery: Code: 42. DB::Exception: Number of arguments for function startsWithUTF8 doesn't match: passed 3, should be 2: In scope SELECT startsWithUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT startsWithUTF8(NULL, NULL, NULL);) 2025.10.23 23:50:11.355926 [ 30720 ] {7f8328e3-4c50-4cdc-83a8-5ce3da797365} TCPHandler: Code: 42. DB::Exception: Number of arguments for function startsWithUTF8 doesn't match: passed 3, should be 2: In scope SELECT startsWithUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:11.518853 [ 3521 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:11.564828 [ 3523 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:11.588254 [ 30720 ] {3b13e563-6ec1-40d8-b680-698711ac4ff8} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT stddevPopStable(NULL, NULL, NULL);) 2025.10.23 23:50:11.635141 [ 30720 ] {3b13e563-6ec1-40d8-b680-698711ac4ff8} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) 2025.10.23 23:50:11.661699 [ 3539 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:11.680546 [ 3518 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:11.819974 [ 3510 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:11.919470 [ 3275 ] {} test_uttb102q.r1 (838ef953-9861-4962-9055-934d1b64d4f5): There is a problem with deleting parts from ZooKeeper: Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000003cc8de51 3. ./src/Common/ZooKeeper/IKeeper.h:509: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003cd16a3e 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000003cd20792 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncExists(String const&, std::function) @ 0x000000003cbe3473 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003855be6b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000385578b8 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000038556f1b 9. ./contrib/llvm-project/libcxx/include/vector:547: DB::StorageReplicatedMergeTree::removePartsFromZooKeeper(std::shared_ptr&, std::vector> const&, std::unordered_set, std::equal_to, std::allocator>*) @ 0x00000000389c2f2b 10. ./contrib/llvm-project/libcxx/include/vector:438: DB::StorageReplicatedMergeTree::clearOldPartsAndRemoveFromZKImpl(std::shared_ptr, std::vector, std::allocator>>&&) @ 0x00000000389bacf4 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::clearOldPartsAndRemoveFromZK() @ 0x00000000389b78d5 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a040863 13. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:50: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a03dd98 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003a06697f 15. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 17. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:11.922253 [ 3275 ] {} test_uttb102q.r1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000003cc8de51 3. ./src/Common/ZooKeeper/IKeeper.h:509: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003cd16a3e 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000003cd20792 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:0: zkutil::ZooKeeper::asyncTryExistsNoThrow(String const&, std::function) @ 0x000000003cbf3581 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003cbf26a1 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000003cbf3a70 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:582: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003cbea871 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000003a0439c9 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a04133c 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:50: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a03dd98 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003a06697f 13. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 15. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:11.950837 [ 30720 ] {1cfd0636-3e81-430c-a486-6d8b4a51d925} executeQuery: Code: 344. DB::Exception: Natural language processing function 'stem' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT stem(NULL, NULL, NULL);) 2025.10.23 23:50:11.954638 [ 30720 ] {1cfd0636-3e81-430c-a486-6d8b4a51d925} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'stem' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.10.23 23:50:11.981899 [ 3499 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:12.049762 [ 30720 ] {4f22bf52-8ecb-4b53-826d-88e3bcd9d934} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT stochasticLinearRegression(NULL, NULL, NULL);) 2025.10.23 23:50:12.055606 [ 30720 ] {4f22bf52-8ecb-4b53-826d-88e3bcd9d934} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) 2025.10.23 23:50:12.357453 [ 30720 ] {d8069d5a-59a8-43b2-99a0-c2e33ddccc94} executeQuery: Code: 42. DB::Exception: Number of arguments for function stringJaccardIndex doesn't match: passed 3, should be 2: In scope SELECT stringJaccardIndex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT stringJaccardIndex(NULL, NULL, NULL);) 2025.10.23 23:50:12.360386 [ 30720 ] {d8069d5a-59a8-43b2-99a0-c2e33ddccc94} TCPHandler: Code: 42. DB::Exception: Number of arguments for function stringJaccardIndex doesn't match: passed 3, should be 2: In scope SELECT stringJaccardIndex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:12.381496 [ 30720 ] {a22ba02c-f521-4e8c-8a95-410125953989} executeQuery: Code: 42. DB::Exception: Number of arguments for function stringJaccardIndexUTF8 doesn't match: passed 3, should be 2: In scope SELECT stringJaccardIndexUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT stringJaccardIndexUTF8(NULL, NULL, NULL);) 2025.10.23 23:50:12.384006 [ 30720 ] {a22ba02c-f521-4e8c-8a95-410125953989} TCPHandler: Code: 42. DB::Exception: Number of arguments for function stringJaccardIndexUTF8 doesn't match: passed 3, should be 2: In scope SELECT stringJaccardIndexUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:12.404673 [ 30720 ] {14d4fddd-257d-47dd-9c52-9acd9a4927e5} executeQuery: Code: 42. DB::Exception: Number of arguments for function stringToH3 doesn't match: passed 3, should be 1: In scope SELECT stringToH3(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT stringToH3(NULL, NULL, NULL);) 2025.10.23 23:50:12.407198 [ 30720 ] {14d4fddd-257d-47dd-9c52-9acd9a4927e5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function stringToH3 doesn't match: passed 3, should be 1: In scope SELECT stringToH3(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:12.444999 [ 30720 ] {a1357727-3de9-457b-91a6-1a20d6559b02} executeQuery: Code: 42. DB::Exception: Number of arguments for function structureToCapnProtoSchema doesn't match: passed 3, expected 1 or 2: In scope SELECT structureToCapnProtoSchema(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT structureToCapnProtoSchema(NULL, NULL, NULL);) 2025.10.23 23:50:12.447437 [ 30720 ] {a1357727-3de9-457b-91a6-1a20d6559b02} TCPHandler: Code: 42. DB::Exception: Number of arguments for function structureToCapnProtoSchema doesn't match: passed 3, expected 1 or 2: In scope SELECT structureToCapnProtoSchema(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:12.520141 [ 3479 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:12.524077 [ 30720 ] {5b7013f2-9647-4aa4-94fc-bc3732158999} executeQuery: Code: 42. DB::Exception: Number of arguments for function structureToProtobufSchema doesn't match: passed 3, expected 1 or 2: In scope SELECT structureToProtobufSchema(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT structureToProtobufSchema(NULL, NULL, NULL);) 2025.10.23 23:50:12.526615 [ 30720 ] {5b7013f2-9647-4aa4-94fc-bc3732158999} TCPHandler: Code: 42. DB::Exception: Number of arguments for function structureToProtobufSchema doesn't match: passed 3, expected 1 or 2: In scope SELECT structureToProtobufSchema(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:12.565776 [ 3491 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:12.663111 [ 3476 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:12.681893 [ 3489 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:12.725773 [ 30720 ] {9face9f2-08d8-4dc0-acdb-401267fa284a} executeQuery: Code: 42. DB::Exception: Number of arguments for function subDate doesn't match: passed 3, should be 2: In scope SELECT subDate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT subDate(NULL, NULL, NULL);) 2025.10.23 23:50:12.728173 [ 30720 ] {9face9f2-08d8-4dc0-acdb-401267fa284a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subDate doesn't match: passed 3, should be 2: In scope SELECT subDate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:12.820966 [ 3472 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:12.982980 [ 3471 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:13.263649 [ 30720 ] {4ee752f4-7cf4-4873-a814-98b894569ece} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractInterval doesn't match: passed 3, should be 2: In scope SELECT subtractInterval(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT subtractInterval(NULL, NULL, NULL);) 2025.10.23 23:50:13.268034 [ 30720 ] {4ee752f4-7cf4-4873-a814-98b894569ece} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractInterval doesn't match: passed 3, should be 2: In scope SELECT subtractInterval(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:13.521072 [ 3467 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:13.566608 [ 3453 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:13.664261 [ 3466 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:13.682845 [ 3446 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:13.821698 [ 3429 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:13.940735 [ 30720 ] {ca826b5e-eebd-4f9c-8262-fb16a610f03a} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractTupleOfIntervals doesn't match: passed 3, should be 2: In scope SELECT subtractTupleOfIntervals(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT subtractTupleOfIntervals(NULL, NULL, NULL);) 2025.10.23 23:50:13.943227 [ 30720 ] {ca826b5e-eebd-4f9c-8262-fb16a610f03a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractTupleOfIntervals doesn't match: passed 3, should be 2: In scope SELECT subtractTupleOfIntervals(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:13.984700 [ 3434 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:14.381699 [ 30720 ] {f3f1633c-bf48-440f-aec6-0087587297b9} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT sumMapFilteredWithOverflow(NULL, NULL, NULL);) 2025.10.23 23:50:14.387240 [ 30720 ] {f3f1633c-bf48-440f-aec6-0087587297b9} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) 2025.10.23 23:50:14.522311 [ 3419 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:14.567667 [ 3451 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:14.665243 [ 3424 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:14.684051 [ 3422 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:14.822617 [ 3410 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:14.874298 [ 30720 ] {f12e832f-40f4-4da0-bf2a-c6dd5c3fc250} executeQuery: Code: 344. DB::Exception: Natural language processing function 'synonyms' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT synonyms(NULL, NULL, NULL);) 2025.10.23 23:50:14.877984 [ 30720 ] {f12e832f-40f4-4da0-bf2a-c6dd5c3fc250} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'synonyms' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.10.23 23:50:14.940562 [ 4841 ] {f9e9e738-345a-4059-b400-bf1bd84485d4} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max rows: 1.00, current rows: 4.00. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:57808) (comment: 02501_limits_on_result_for_view.sql) (in query: -- test SELECT * from 02501_view settings max_result_rows = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x00000000323602d7 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:24: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000003235fdb0 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:64: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x00000000323601ec 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000003b8688f0 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acdc84 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae66ecb 9. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:50:14.944220 [ 4799 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:37546, 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x00000000204bfd30 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x00000000204c0cc1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a8112cd 6. DB::ReadBuffer::next() @ 0x00000000095b468f 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000003abd729e 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:14.945864 [ 4841 ] {f9e9e738-345a-4059-b400-bf1bd84485d4} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max rows: 1.00, current rows: 4.00. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x00000000323602d7 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:24: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000003235fdb0 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:64: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x00000000323601ec 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000003b8688f0 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acdc84 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae66ecb 9. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:50:14.986025 [ 3407 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:14.992987 [ 30720 ] {59843cbf-0512-4d69-8b03-e17ac72c7ea5} executeQuery: Code: 42. DB::Exception: Number of arguments for function tan doesn't match: passed 3, should be 1: In scope SELECT tan(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tan(NULL, NULL, NULL);) 2025.10.23 23:50:14.996872 [ 30720 ] {59843cbf-0512-4d69-8b03-e17ac72c7ea5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tan doesn't match: passed 3, should be 1: In scope SELECT tan(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:15.170073 [ 30720 ] {56ba5344-277f-4753-9fba-de88700c8c6f} executeQuery: Code: 42. DB::Exception: Number of arguments for function tanh doesn't match: passed 3, should be 1: In scope SELECT tanh(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tanh(NULL, NULL, NULL);) 2025.10.23 23:50:15.174823 [ 30720 ] {56ba5344-277f-4753-9fba-de88700c8c6f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tanh doesn't match: passed 3, should be 1: In scope SELECT tanh(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:15.207213 [ 30720 ] {cd69d186-216e-49a5-a3bc-3f7f4fcaf362} executeQuery: Code: 42. DB::Exception: Number of arguments for function tcpPort doesn't match: passed 3, should be 0: In scope SELECT tcpPort(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tcpPort(NULL, NULL, NULL);) 2025.10.23 23:50:15.211320 [ 30720 ] {cd69d186-216e-49a5-a3bc-3f7f4fcaf362} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tcpPort doesn't match: passed 3, should be 0: In scope SELECT tcpPort(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:15.321007 [ 30720 ] {2715a3c7-06e0-41d3-9faa-49521a2c7121} executeQuery: Code: 42. DB::Exception: Number of arguments for function test_function doesn't match: passed 3, should be 2: In scope SELECT test_function(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT test_function(NULL, NULL, NULL);) 2025.10.23 23:50:15.324775 [ 30720 ] {2715a3c7-06e0-41d3-9faa-49521a2c7121} TCPHandler: Code: 42. DB::Exception: Number of arguments for function test_function doesn't match: passed 3, should be 2: In scope SELECT test_function(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:15.427437 [ 30720 ] {a3977784-d2c4-4ebf-90c4-9ba6381ea19b} executeQuery: Code: 42. DB::Exception: Number of arguments for function tgamma doesn't match: passed 3, should be 1: In scope SELECT tgamma(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tgamma(NULL, NULL, NULL);) 2025.10.23 23:50:15.431289 [ 30720 ] {a3977784-d2c4-4ebf-90c4-9ba6381ea19b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tgamma doesn't match: passed 3, should be 1: In scope SELECT tgamma(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:15.491152 [ 4841 ] {85c69d92-483b-4277-a3c3-884491af67d5} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:57808) (comment: 02501_limits_on_result_for_view.sql) (in query: DROP VIEW IF EXISTS 02501_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000002ffc5e67 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003493f2d5 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:50:15.493080 [ 4841 ] {85c69d92-483b-4277-a3c3-884491af67d5} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000002ffc5e67 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003493f2d5 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:50:15.523487 [ 3384 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:15.568751 [ 3390 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:15.666637 [ 3386 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:15.685275 [ 3388 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:15.700222 [ 30720 ] {032e847b-4e54-4333-92d1-b225e641972c} executeQuery: Code: 42. DB::Exception: Number of arguments for function tid doesn't match: passed 3, should be 0: In scope SELECT tid(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tid(NULL, NULL, NULL);) 2025.10.23 23:50:15.702781 [ 30720 ] {032e847b-4e54-4333-92d1-b225e641972c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tid doesn't match: passed 3, should be 0: In scope SELECT tid(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:15.816896 [ 30720 ] {28a020c4-2b26-4e8e-bf53-99c5fc603fbc} executeQuery: Code: 42. DB::Exception: Number of arguments for function timeDiff doesn't match: passed 3, should be 2: In scope SELECT timeDiff(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT timeDiff(NULL, NULL, NULL);) 2025.10.23 23:50:15.819284 [ 30720 ] {28a020c4-2b26-4e8e-bf53-99c5fc603fbc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timeDiff doesn't match: passed 3, should be 2: In scope SELECT timeDiff(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:15.823412 [ 3389 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:15.957811 [ 30720 ] {6b7d418f-7791-4483-bcef-5e9377e3ab28} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezone doesn't match: passed 3, should be 0: In scope SELECT timeZone(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT timeZone(NULL, NULL, NULL);) 2025.10.23 23:50:15.986977 [ 3367 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:16.018817 [ 30720 ] {6b7d418f-7791-4483-bcef-5e9377e3ab28} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezone doesn't match: passed 3, should be 0: In scope SELECT timeZone(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:16.040051 [ 30720 ] {8adb045b-ac8b-4db5-bcc6-2f5eaf65a616} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezoneOf doesn't match: passed 3, should be 1: In scope SELECT timeZoneOf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT timeZoneOf(NULL, NULL, NULL);) 2025.10.23 23:50:16.042515 [ 30720 ] {8adb045b-ac8b-4db5-bcc6-2f5eaf65a616} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezoneOf doesn't match: passed 3, should be 1: In scope SELECT timeZoneOf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:16.420729 [ 30720 ] {1e2e5cca-9f61-4fcc-9f5c-568b7ba2a991} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezone doesn't match: passed 3, should be 0: In scope SELECT timezone(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT timezone(NULL, NULL, NULL);) 2025.10.23 23:50:16.423202 [ 30720 ] {1e2e5cca-9f61-4fcc-9f5c-568b7ba2a991} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezone doesn't match: passed 3, should be 0: In scope SELECT timezone(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:16.443679 [ 30720 ] {d93971ae-5483-4863-a074-6c844b661b3c} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezoneOf doesn't match: passed 3, should be 1: In scope SELECT timezoneOf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT timezoneOf(NULL, NULL, NULL);) 2025.10.23 23:50:16.446193 [ 30720 ] {d93971ae-5483-4863-a074-6c844b661b3c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezoneOf doesn't match: passed 3, should be 1: In scope SELECT timezoneOf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:16.497197 [ 30720 ] {9a51a875-fdf6-4bae-86f2-fba3cf8a9777} executeQuery: Code: 42. DB::Exception: Number of arguments for function toBool doesn't match: passed 3, should be 1: In scope SELECT toBool(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toBool(NULL, NULL, NULL);) 2025.10.23 23:50:16.499408 [ 30720 ] {9a51a875-fdf6-4bae-86f2-fba3cf8a9777} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toBool doesn't match: passed 3, should be 1: In scope SELECT toBool(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:16.516191 [ 30720 ] {de1c313b-9a47-4326-8616-f4186fbf8e7b} executeQuery: Code: 42. DB::Exception: Number of arguments for function toColumnTypeName doesn't match: passed 3, should be 1: In scope SELECT toColumnTypeName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toColumnTypeName(NULL, NULL, NULL);) 2025.10.23 23:50:16.518322 [ 30720 ] {de1c313b-9a47-4326-8616-f4186fbf8e7b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toColumnTypeName doesn't match: passed 3, should be 1: In scope SELECT toColumnTypeName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:16.524690 [ 3382 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:16.569646 [ 3364 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:16.620860 [ 30720 ] {63be3f0c-29d0-43cf-a305-b93af3760018} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDate32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toDate32OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toDate32OrDefault(NULL, NULL, NULL);) 2025.10.23 23:50:16.623138 [ 30720 ] {63be3f0c-29d0-43cf-a305-b93af3760018} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDate32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toDate32OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:16.668564 [ 3379 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:16.686382 [ 3359 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:16.702447 [ 30720 ] {5b6064c3-7c39-49f6-94dd-27e3f89b98af} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateOrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toDateOrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toDateOrDefault(NULL, NULL, NULL);) 2025.10.23 23:50:16.704737 [ 30720 ] {5b6064c3-7c39-49f6-94dd-27e3f89b98af} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateOrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toDateOrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:16.824676 [ 3352 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:16.988140 [ 3339 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:17.124913 [ 30720 ] {5df9ee46-11fb-439e-ab64-1cd4ef8e211a} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDateTime64OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDateTime64OrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toDateTime64OrDefault(NULL, NULL, NULL);) 2025.10.23 23:50:17.213797 [ 30720 ] {5df9ee46-11fb-439e-ab64-1cd4ef8e211a} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDateTime64OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDateTime64OrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:50:17.363055 [ 30720 ] {e6cddc2b-54e7-4b94-867a-569d30f7d295} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'timezone' to function 'toDateTimeOrDefault'. Expected: const String, got: Nullable(Nothing): In scope SELECT toDateTimeOrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toDateTimeOrDefault(NULL, NULL, NULL);) 2025.10.23 23:50:17.366847 [ 30720 ] {e6cddc2b-54e7-4b94-867a-569d30f7d295} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'timezone' to function 'toDateTimeOrDefault'. Expected: const String, got: Nullable(Nothing): In scope SELECT toDateTimeOrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:50:17.525656 [ 3346 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:17.570728 [ 3357 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:17.670435 [ 3328 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:17.687603 [ 3342 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:17.825835 [ 3373 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:17.989352 [ 3338 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:18.203331 [ 30720 ] {ea4f76f6-5c76-4ebe-ba57-2530520506b3} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal128OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal128OrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toDecimal128OrDefault(NULL, NULL, NULL);) 2025.10.23 23:50:18.205836 [ 30720 ] {ea4f76f6-5c76-4ebe-ba57-2530520506b3} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal128OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal128OrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:50:18.491772 [ 30720 ] {1f9da300-5815-4571-982d-9d27ca98be03} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal256OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal256OrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toDecimal256OrDefault(NULL, NULL, NULL);) 2025.10.23 23:50:18.493870 [ 30720 ] {1f9da300-5815-4571-982d-9d27ca98be03} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal256OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal256OrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:50:18.526488 [ 3348 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:18.572321 [ 3298 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:18.672359 [ 3309 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:18.688943 [ 3311 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:18.772492 [ 30720 ] {92e86888-6b07-45b9-beab-a30d219df32a} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal32OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal32OrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toDecimal32OrDefault(NULL, NULL, NULL);) 2025.10.23 23:50:18.776518 [ 30720 ] {92e86888-6b07-45b9-beab-a30d219df32a} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal32OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal32OrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:50:18.784229 [ 4841 ] {8bb2adb2-8c38-48f1-8e97-5686a9970131} executeQuery: Code: 41. DB::Exception: Cannot read DateTime: unexpected word: In scope SELECT toDayOfWeek('invalid'). (CANNOT_PARSE_DATETIME) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:47708) (comment: 01661_week_functions_string_args.sql) (in query: SELECT toDayOfWeek('invalid');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:99: auto void DB::(anonymous namespace)::parseDateTimeBestEffortImpl(long&, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&, DB::(anonymous namespace)::DateTimeSubsecondPart*, char const*)::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000020272ad4 5. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:0: DB::parseDateTime64BestEffort(DB::DateTime64&, unsigned int, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&) @ 0x0000000020245464 6. COW::immutable_ptr DB::CustomWeekTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToDayOfWeekImpl) @ 0x000000001c5e2e47 7. DB::FunctionCustomWeekToSomething, DB::ToDayOfWeekImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c5dcb62 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:50:18.786885 [ 4841 ] {8bb2adb2-8c38-48f1-8e97-5686a9970131} TCPHandler: Code: 41. DB::Exception: Cannot read DateTime: unexpected word: In scope SELECT toDayOfWeek('invalid'). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:99: auto void DB::(anonymous namespace)::parseDateTimeBestEffortImpl(long&, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&, DB::(anonymous namespace)::DateTimeSubsecondPart*, char const*)::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000020272ad4 5. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:0: DB::parseDateTime64BestEffort(DB::DateTime64&, unsigned int, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&) @ 0x0000000020245464 6. COW::immutable_ptr DB::CustomWeekTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToDayOfWeekImpl) @ 0x000000001c5e2e47 7. DB::FunctionCustomWeekToSomething, DB::ToDayOfWeekImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c5dcb62 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:50:18.826940 [ 3300 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:18.990683 [ 3299 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:19.361326 [ 30720 ] {cb5dc166-2539-4650-8c5f-2ca2c09926a6} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal64OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal64OrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toDecimal64OrDefault(NULL, NULL, NULL);) 2025.10.23 23:50:19.364258 [ 30720 ] {cb5dc166-2539-4650-8c5f-2ca2c09926a6} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal64OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal64OrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:50:19.527220 [ 3284 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:19.532404 [ 30720 ] {aae43007-2d6c-4189-9230-1ef256166569} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimalString doesn't match: passed 3, should be 2: In scope SELECT toDecimalString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toDecimalString(NULL, NULL, NULL);) 2025.10.23 23:50:19.534864 [ 30720 ] {aae43007-2d6c-4189-9230-1ef256166569} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimalString doesn't match: passed 3, should be 2: In scope SELECT toDecimalString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:19.553001 [ 30720 ] {dd9b6158-31ed-4ff8-aa1c-52ff480c68f3} executeQuery: Code: 42. DB::Exception: Number of arguments for function toFixedString doesn't match: passed 3, should be 2: In scope SELECT toFixedString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toFixedString(NULL, NULL, NULL);) 2025.10.23 23:50:19.555265 [ 30720 ] {dd9b6158-31ed-4ff8-aa1c-52ff480c68f3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toFixedString doesn't match: passed 3, should be 2: In scope SELECT toFixedString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:19.573384 [ 3283 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:19.673403 [ 3277 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:19.690254 [ 3310 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:19.715250 [ 30720 ] {34bae61d-9300-45fb-8e64-0ced4deed0df} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toFloat32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toFloat32OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toFloat32OrDefault(NULL, NULL, NULL);) 2025.10.23 23:50:19.717815 [ 30720 ] {34bae61d-9300-45fb-8e64-0ced4deed0df} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toFloat32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toFloat32OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:19.828017 [ 3276 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:19.927838 [ 30720 ] {26fb9753-37d6-4abd-aebd-65da7602ab64} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toFloat64OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toFloat64OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toFloat64OrDefault(NULL, NULL, NULL);) 2025.10.23 23:50:19.931404 [ 30720 ] {26fb9753-37d6-4abd-aebd-65da7602ab64} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toFloat64OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toFloat64OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:19.991651 [ 3270 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:20.394020 [ 30720 ] {b26285bb-cb97-48b3-a2fa-5d68926af686} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIPv4OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toIPv4OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toIPv4OrDefault(NULL, NULL, NULL);) 2025.10.23 23:50:20.444120 [ 30720 ] {b26285bb-cb97-48b3-a2fa-5d68926af686} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIPv4OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toIPv4OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:20.528160 [ 3249 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:20.574275 [ 3233 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:20.674638 [ 3247 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:20.691552 [ 3227 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:20.829250 [ 3226 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:20.874536 [ 30720 ] {cc99f4dd-78b7-444b-a60d-b7686521e363} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIPv6OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toIPv6OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toIPv6OrDefault(NULL, NULL, NULL);) 2025.10.23 23:50:20.878551 [ 30720 ] {cc99f4dd-78b7-444b-a60d-b7686521e363} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIPv6OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toIPv6OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:20.992703 [ 3230 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:21.271656 [ 30720 ] {78041bbc-e78d-490d-9325-72ef75c36024} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt128OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt128OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toInt128OrDefault(NULL, NULL, NULL);) 2025.10.23 23:50:21.274561 [ 30720 ] {78041bbc-e78d-490d-9325-72ef75c36024} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt128OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt128OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:21.397472 [ 30720 ] {4290109f-10ce-41b9-be59-d15ba92d862c} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt16OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt16OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toInt16OrDefault(NULL, NULL, NULL);) 2025.10.23 23:50:21.400045 [ 30720 ] {4290109f-10ce-41b9-be59-d15ba92d862c} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt16OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt16OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:21.529179 [ 3212 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:21.570959 [ 30720 ] {4a8f1527-279f-481f-a46c-66fd3a151d2c} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt256OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt256OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toInt256OrDefault(NULL, NULL, NULL);) 2025.10.23 23:50:21.574577 [ 30720 ] {4a8f1527-279f-481f-a46c-66fd3a151d2c} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt256OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt256OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:21.575452 [ 3210 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:21.676000 [ 3208 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:21.693283 [ 3199 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:21.696172 [ 30720 ] {341ff1f2-9a15-4aaf-bed8-63cc66263ac3} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt32OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toInt32OrDefault(NULL, NULL, NULL);) 2025.10.23 23:50:21.698469 [ 30720 ] {341ff1f2-9a15-4aaf-bed8-63cc66263ac3} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt32OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:21.729149 [ 4841 ] {34a32072-e8ed-473d-9726-344fe6f8a64a} executeQuery: Code: 41. DB::Exception: Cannot read DateTime: unexpected word: In scope SELECT toWeek('invalid'). (CANNOT_PARSE_DATETIME) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:47708) (comment: 01661_week_functions_string_args.sql) (in query: SELECT toWeek('invalid');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:99: auto void DB::(anonymous namespace)::parseDateTimeBestEffortImpl(long&, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&, DB::(anonymous namespace)::DateTimeSubsecondPart*, char const*)::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000020272ad4 5. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:0: DB::parseDateTime64BestEffort(DB::DateTime64&, unsigned int, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&) @ 0x0000000020245464 6. COW::immutable_ptr DB::CustomWeekTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToWeekImpl) @ 0x000000001c5ae681 7. DB::FunctionCustomWeekToSomething, DB::ToWeekImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c5a8902 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:50:21.731560 [ 4841 ] {34a32072-e8ed-473d-9726-344fe6f8a64a} TCPHandler: Code: 41. DB::Exception: Cannot read DateTime: unexpected word: In scope SELECT toWeek('invalid'). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:99: auto void DB::(anonymous namespace)::parseDateTimeBestEffortImpl(long&, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&, DB::(anonymous namespace)::DateTimeSubsecondPart*, char const*)::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000020272ad4 5. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:0: DB::parseDateTime64BestEffort(DB::DateTime64&, unsigned int, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&) @ 0x0000000020245464 6. COW::immutable_ptr DB::CustomWeekTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToWeekImpl) @ 0x000000001c5ae681 7. DB::FunctionCustomWeekToSomething, DB::ToWeekImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c5a8902 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:50:21.830434 [ 3198 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:21.834350 [ 30720 ] {24daf12e-e84f-490e-95f0-8f65526fd7b8} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt64OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt64OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toInt64OrDefault(NULL, NULL, NULL);) 2025.10.23 23:50:21.982238 [ 30720 ] {24daf12e-e84f-490e-95f0-8f65526fd7b8} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt64OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt64OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:21.993742 [ 3205 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:22.183212 [ 30720 ] {14f844cf-697c-4aab-aebc-2edf9b5d889d} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt8OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt8OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toInt8OrDefault(NULL, NULL, NULL);) 2025.10.23 23:50:22.186408 [ 30720 ] {14f844cf-697c-4aab-aebc-2edf9b5d889d} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt8OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt8OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:22.530055 [ 3182 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:22.576614 [ 3178 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:22.677330 [ 3170 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:22.694870 [ 3175 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:22.831484 [ 3173 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:22.994835 [ 3195 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:23.002876 [ 30720 ] {3975cecc-c959-4bce-b8b7-64cf9528d42c} executeQuery: Code: 42. DB::Exception: Number of arguments for function toJSONString doesn't match: passed 3, should be 1: In scope SELECT toJSONString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toJSONString(NULL, NULL, NULL);) 2025.10.23 23:50:23.006309 [ 30720 ] {3975cecc-c959-4bce-b8b7-64cf9528d42c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toJSONString doesn't match: passed 3, should be 1: In scope SELECT toJSONString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:23.286656 [ 30720 ] {644d8ffa-102e-4de2-8c25-72e10d20c966} executeQuery: Code: 42. DB::Exception: Number of arguments for function toLowCardinality doesn't match: passed 3, should be 1: In scope SELECT toLowCardinality(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toLowCardinality(NULL, NULL, NULL);) 2025.10.23 23:50:23.289737 [ 30720 ] {644d8ffa-102e-4de2-8c25-72e10d20c966} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toLowCardinality doesn't match: passed 3, should be 1: In scope SELECT toLowCardinality(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:23.531134 [ 3161 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:23.577533 [ 3517 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:23.627062 [ 30720 ] {8e318db6-f99f-4ab5-83b8-d16276baf35b} executeQuery: Code: 42. DB::Exception: Number of arguments for function toModifiedJulianDay doesn't match: passed 3, should be 1: In scope SELECT toModifiedJulianDay(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toModifiedJulianDay(NULL, NULL, NULL);) 2025.10.23 23:50:23.629841 [ 30720 ] {8e318db6-f99f-4ab5-83b8-d16276baf35b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toModifiedJulianDay doesn't match: passed 3, should be 1: In scope SELECT toModifiedJulianDay(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:23.654095 [ 30720 ] {22858897-a000-4720-9718-4a8096570146} executeQuery: Code: 42. DB::Exception: Number of arguments for function toModifiedJulianDayOrNull doesn't match: passed 3, should be 1: In scope SELECT toModifiedJulianDayOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toModifiedJulianDayOrNull(NULL, NULL, NULL);) 2025.10.23 23:50:23.656867 [ 30720 ] {22858897-a000-4720-9718-4a8096570146} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toModifiedJulianDayOrNull doesn't match: passed 3, should be 1: In scope SELECT toModifiedJulianDayOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:23.678601 [ 3154 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:23.696220 [ 3145 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:23.745825 [ 30720 ] {93aabca9-0e5b-495b-8ae8-e2e0305c1bfd} executeQuery: Code: 42. DB::Exception: Number of arguments for function toNullable doesn't match: passed 3, should be 1: In scope SELECT toNullable(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toNullable(NULL, NULL, NULL);) 2025.10.23 23:50:23.748225 [ 30720 ] {93aabca9-0e5b-495b-8ae8-e2e0305c1bfd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toNullable doesn't match: passed 3, should be 1: In scope SELECT toNullable(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:23.795906 [ 4841 ] {0b31153f-972f-4b07-9632-54dba82fed47} executeQuery: Code: 41. DB::Exception: Cannot read DateTime: unexpected word: In scope SELECT toYearWeek('invalid'). (CANNOT_PARSE_DATETIME) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:47708) (comment: 01661_week_functions_string_args.sql) (in query: SELECT toYearWeek('invalid');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:99: auto void DB::(anonymous namespace)::parseDateTimeBestEffortImpl(long&, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&, DB::(anonymous namespace)::DateTimeSubsecondPart*, char const*)::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000020272ad4 5. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:0: DB::parseDateTime64BestEffort(DB::DateTime64&, unsigned int, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&) @ 0x0000000020245464 6. COW::immutable_ptr DB::CustomWeekTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToYearWeekImpl) @ 0x000000001c5b7bc1 7. DB::FunctionCustomWeekToSomething, DB::ToYearWeekImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c5b2bc2 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:50:23.798053 [ 4841 ] {0b31153f-972f-4b07-9632-54dba82fed47} TCPHandler: Code: 41. DB::Exception: Cannot read DateTime: unexpected word: In scope SELECT toYearWeek('invalid'). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:99: auto void DB::(anonymous namespace)::parseDateTimeBestEffortImpl(long&, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&, DB::(anonymous namespace)::DateTimeSubsecondPart*, char const*)::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000020272ad4 5. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:0: DB::parseDateTime64BestEffort(DB::DateTime64&, unsigned int, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&) @ 0x0000000020245464 6. COW::immutable_ptr DB::CustomWeekTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToYearWeekImpl) @ 0x000000001c5b7bc1 7. DB::FunctionCustomWeekToSomething, DB::ToYearWeekImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c5b2bc2 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:50:23.832388 [ 3149 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:23.996282 [ 3177 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:24.532590 [ 3136 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:24.578486 [ 3119 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:24.679988 [ 3140 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:24.697149 [ 3114 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:24.833129 [ 3108 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:24.997914 [ 3109 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:25.533681 [ 3082 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:25.579305 [ 3088 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:25.681396 [ 3087 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:25.698518 [ 3096 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:25.833895 [ 3086 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:25.999129 [ 3084 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:26.207184 [ 30720 ] {00ec1ea2-da9c-4655-b5df-5450193b3dde} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStringCutToZero doesn't match: passed 3, should be 1: In scope SELECT toStringCutToZero(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toStringCutToZero(NULL, NULL, NULL);) 2025.10.23 23:50:26.209724 [ 30720 ] {00ec1ea2-da9c-4655-b5df-5450193b3dde} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStringCutToZero doesn't match: passed 3, should be 1: In scope SELECT toStringCutToZero(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:26.289955 [ 30720 ] {3a7bd6b6-0486-4930-9f6c-7450286b9e65} executeQuery: Code: 42. DB::Exception: Number of arguments for function toTimezone doesn't match: passed 3, should be 2: In scope SELECT toTimeZone(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toTimeZone(NULL, NULL, NULL);) 2025.10.23 23:50:26.292761 [ 30720 ] {3a7bd6b6-0486-4930-9f6c-7450286b9e65} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toTimezone doesn't match: passed 3, should be 2: In scope SELECT toTimeZone(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:26.314544 [ 30720 ] {300e1abb-a01d-4ae5-944c-271f6e4b4f80} executeQuery: Code: 42. DB::Exception: Number of arguments for function toTimezone doesn't match: passed 3, should be 2: In scope SELECT toTimezone(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toTimezone(NULL, NULL, NULL);) 2025.10.23 23:50:26.317096 [ 30720 ] {300e1abb-a01d-4ae5-944c-271f6e4b4f80} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toTimezone doesn't match: passed 3, should be 2: In scope SELECT toTimezone(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:26.488329 [ 30720 ] {51c1853f-789c-4ede-bf1e-8be8e4f85614} executeQuery: Code: 42. DB::Exception: Number of arguments for function toTypeName doesn't match: passed 3, should be 1: In scope SELECT toTypeName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toTypeName(NULL, NULL, NULL);) 2025.10.23 23:50:26.490767 [ 30720 ] {51c1853f-789c-4ede-bf1e-8be8e4f85614} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toTypeName doesn't match: passed 3, should be 1: In scope SELECT toTypeName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:26.534534 [ 3064 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:26.555198 [ 30720 ] {792005e0-b126-4967-a745-dffdf6fa2965} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt128OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt128OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toUInt128OrDefault(NULL, NULL, NULL);) 2025.10.23 23:50:26.557814 [ 30720 ] {792005e0-b126-4967-a745-dffdf6fa2965} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt128OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt128OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:26.580228 [ 3104 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:26.682560 [ 3068 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:26.699862 [ 3069 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:26.834560 [ 3073 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:26.942567 [ 30720 ] {e1a80c94-d30b-4eca-8455-630bebe32c9e} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt16OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt16OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toUInt16OrDefault(NULL, NULL, NULL);) 2025.10.23 23:50:26.945469 [ 30720 ] {e1a80c94-d30b-4eca-8455-630bebe32c9e} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt16OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt16OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:27.000396 [ 3062 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:27.300252 [ 30720 ] {9e1cf9a7-934b-404c-817a-61b39c95f0bd} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt256OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt256OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toUInt256OrDefault(NULL, NULL, NULL);) 2025.10.23 23:50:27.302469 [ 30720 ] {9e1cf9a7-934b-404c-817a-61b39c95f0bd} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt256OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt256OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:27.535284 [ 3433 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:27.545764 [ 30720 ] {0d6f3532-f09c-45d6-b556-fa5edd18c3c1} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt32OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toUInt32OrDefault(NULL, NULL, NULL);) 2025.10.23 23:50:27.548529 [ 30720 ] {0d6f3532-f09c-45d6-b556-fa5edd18c3c1} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt32OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:27.581007 [ 3296 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:27.683900 [ 3291 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:27.700961 [ 3124 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:27.759117 [ 30720 ] {1052234d-2d55-4fda-bb3e-9dc70bb75992} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt64OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt64OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toUInt64OrDefault(NULL, NULL, NULL);) 2025.10.23 23:50:27.762005 [ 30720 ] {1052234d-2d55-4fda-bb3e-9dc70bb75992} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt64OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt64OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:27.835602 [ 3141 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:27.966631 [ 30720 ] {71f1608b-99c9-4908-bf2a-b6803eb8abbc} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt8OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt8OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toUInt8OrDefault(NULL, NULL, NULL);) 2025.10.23 23:50:27.969577 [ 30720 ] {71f1608b-99c9-4908-bf2a-b6803eb8abbc} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt8OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt8OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:28.001632 [ 3098 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:28.264234 [ 30720 ] {ba6dd7a9-bc99-4dae-99e7-63258e2c6c62} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUTCTimestamp doesn't match: passed 3, should be 2: In scope SELECT toUTCTimestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toUTCTimestamp(NULL, NULL, NULL);) 2025.10.23 23:50:28.266729 [ 30720 ] {ba6dd7a9-bc99-4dae-99e7-63258e2c6c62} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUTCTimestamp doesn't match: passed 3, should be 2: In scope SELECT toUTCTimestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:28.391117 [ 30720 ] {a41213c4-c299-4678-ae72-9c01b7bac5aa} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUUIDOrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUUIDOrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toUUIDOrDefault(NULL, NULL, NULL);) 2025.10.23 23:50:28.395107 [ 30720 ] {a41213c4-c299-4678-ae72-9c01b7bac5aa} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUUIDOrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUUIDOrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:28.536290 [ 3552 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:28.581901 [ 3534 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:28.584809 [ 30720 ] {f185c119-f213-4706-8aaf-b74c21edb872} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Micro doesn't match: passed 3, should be 1: In scope SELECT toUnixTimestamp64Micro(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toUnixTimestamp64Micro(NULL, NULL, NULL);) 2025.10.23 23:50:28.588709 [ 30720 ] {f185c119-f213-4706-8aaf-b74c21edb872} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Micro doesn't match: passed 3, should be 1: In scope SELECT toUnixTimestamp64Micro(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:28.635867 [ 30720 ] {b168f453-0dae-4b35-9abf-0d304927f785} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Milli doesn't match: passed 3, should be 1: In scope SELECT toUnixTimestamp64Milli(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toUnixTimestamp64Milli(NULL, NULL, NULL);) 2025.10.23 23:50:28.639484 [ 30720 ] {b168f453-0dae-4b35-9abf-0d304927f785} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Milli doesn't match: passed 3, should be 1: In scope SELECT toUnixTimestamp64Milli(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:28.685332 [ 3535 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:28.702270 [ 3527 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:28.745938 [ 30720 ] {759581b0-dc9a-4fc5-9420-89480f38cc0a} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Nano doesn't match: passed 3, should be 1: In scope SELECT toUnixTimestamp64Nano(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toUnixTimestamp64Nano(NULL, NULL, NULL);) 2025.10.23 23:50:28.837016 [ 3528 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:28.853299 [ 30720 ] {759581b0-dc9a-4fc5-9420-89480f38cc0a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Nano doesn't match: passed 3, should be 1: In scope SELECT toUnixTimestamp64Nano(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:28.880199 [ 30720 ] {678522bc-fb13-4f23-b148-b06834a6b759} executeQuery: Code: 42. DB::Exception: Number of arguments for function toValidUTF8 doesn't match: passed 3, should be 1: In scope SELECT toValidUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toValidUTF8(NULL, NULL, NULL);) 2025.10.23 23:50:28.884081 [ 30720 ] {678522bc-fb13-4f23-b148-b06834a6b759} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toValidUTF8 doesn't match: passed 3, should be 1: In scope SELECT toValidUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:28.921448 [ 30720 ] {e49ab29e-e800-46bf-883c-7b12e461b74f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=749). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toWeek(NULL, NULL, NULL);) 2025.10.23 23:50:28.924495 [ 30720 ] {e49ab29e-e800-46bf-883c-7b12e461b74f} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=749). (CANNOT_SCHEDULE_TASK) 2025.10.23 23:50:29.068398 [ 3554 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:29.158998 [ 4841 ] {647d65d4-de2e-466b-8c5d-7c2814e2483b} executeQuery: Code: 41. DB::Exception: Cannot read DateTime: unexpected word: while executing 'FUNCTION toDayOfWeek(__table1.invalid :: 1) -> toDayOfWeek(__table1.invalid) UInt8 : 0'. (CANNOT_PARSE_DATETIME) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:47708) (comment: 01661_week_functions_string_args.sql) (in query: SELECT toDayOfWeek(invalid) FROM `tab`;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:99: auto void DB::(anonymous namespace)::parseDateTimeBestEffortImpl(long&, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&, DB::(anonymous namespace)::DateTimeSubsecondPart*, char const*)::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000020272ad4 5. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:0: DB::parseDateTime64BestEffort(DB::DateTime64&, unsigned int, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&) @ 0x0000000020245464 6. COW::immutable_ptr DB::CustomWeekTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToDayOfWeekImpl) @ 0x000000001c5e2e47 7. DB::FunctionCustomWeekToSomething, DB::ToDayOfWeekImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c5dcb62 8. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d57db 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffeaa 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a24ade 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b82c484 14. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acdc84 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae66ecb 16. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 21. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 2025.10.23 23:50:29.162141 [ 4841 ] {647d65d4-de2e-466b-8c5d-7c2814e2483b} TCPHandler: Code: 41. DB::Exception: Cannot read DateTime: unexpected word: while executing 'FUNCTION toDayOfWeek(__table1.invalid :: 1) -> toDayOfWeek(__table1.invalid) UInt8 : 0'. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:99: auto void DB::(anonymous namespace)::parseDateTimeBestEffortImpl(long&, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&, DB::(anonymous namespace)::DateTimeSubsecondPart*, char const*)::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000020272ad4 5. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:0: DB::parseDateTime64BestEffort(DB::DateTime64&, unsigned int, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&) @ 0x0000000020245464 6. COW::immutable_ptr DB::CustomWeekTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToDayOfWeekImpl) @ 0x000000001c5e2e47 7. DB::FunctionCustomWeekToSomething, DB::ToDayOfWeekImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c5dcb62 8. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d57db 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffeaa 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a24ade 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b82c484 14. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acdc84 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae66ecb 16. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 21. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 2025.10.23 23:50:29.282601 [ 30720 ] {3f6c46d8-aa81-47b0-a1ab-ba02888dcf1c} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUTCTimestamp doesn't match: passed 3, should be 2: In scope SELECT to_utc_timestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT to_utc_timestamp(NULL, NULL, NULL);) 2025.10.23 23:50:29.287482 [ 30720 ] {3f6c46d8-aa81-47b0-a1ab-ba02888dcf1c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUTCTimestamp doesn't match: passed 3, should be 2: In scope SELECT to_utc_timestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:29.369970 [ 30720 ] {24b1e745-c609-4ffd-a27e-97060385bac9} executeQuery: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 3, should be 0: In scope SELECT today(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT today(NULL, NULL, NULL);) 2025.10.23 23:50:29.373869 [ 30720 ] {24b1e745-c609-4ffd-a27e-97060385bac9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 3, should be 0: In scope SELECT today(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:29.438606 [ 2903 ] {02f698ee-4525-4e47-83eb-ee6c2e987175} 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.10542.altinitytest (altinity build)) (from [::1]:47748) (comment: 01396_inactive_replica_cleanup_nodes_zookeeper.sh) (in query: SELECT sum(toUInt32(extract(message, 'Removed (\d+) old log entries'))) FROM system.text_log WHERE event_date >= yesterday() AND logger_name LIKE '%' || 'test_uttb102q' || '%r1%(ReplicatedMergeTreeCleanupThread)%' AND message LIKE '%Removed % old log entries%'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000039d07892 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&) @ 0x0000000039d09d4a 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:63: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x00000000326402a2 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000032640cad 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000039d01224 14. ./contrib/llvm-project/libcxx/include/vector:547: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000039d00b49 15. ./contrib/llvm-project/libcxx/include/__tree:1088: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) @ 0x00000000399bb1c8 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 @ 0x00000000399b0254 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039d46d05 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003bfd663a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c083c53 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003bfe2b53 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d3c440 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf89b85 23. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 24. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 28. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 31. ? @ 0x00007f100c857ac3 2025.10.23 23:50:29.447441 [ 2903 ] {02f698ee-4525-4e47-83eb-ee6c2e987175} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000039d07892 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&) @ 0x0000000039d09d4a 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:63: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x00000000326402a2 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000032640cad 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000039d01224 14. ./contrib/llvm-project/libcxx/include/vector:547: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000039d00b49 15. ./contrib/llvm-project/libcxx/include/__tree:1088: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) @ 0x00000000399bb1c8 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 @ 0x00000000399b0254 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039d46d05 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003bfd663a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c083c53 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003bfe2b53 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d3c440 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf89b85 23. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 24. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 28. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 31. ? @ 0x00007f100c857ac3 2025.10.23 23:50:29.457039 [ 30720 ] {5b70d325-d55c-4567-9584-6877546d62c8} executeQuery: Code: 42. DB::Exception: Number of arguments for function tokens doesn't match: passed 3, should be 1: In scope SELECT tokens(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tokens(NULL, NULL, NULL);) 2025.10.23 23:50:29.461801 [ 30720 ] {5b70d325-d55c-4567-9584-6877546d62c8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tokens doesn't match: passed 3, should be 1: In scope SELECT tokens(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:29.537387 [ 3547 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:29.582927 [ 3537 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:29.638419 [ 30720 ] {5f2cb0d0-619b-4f33-865d-e2fcea554917} executeQuery: Code: 42. DB::Exception: Number of arguments for function topLevelDomain doesn't match: passed 3, should be 1: In scope SELECT topLevelDomain(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT topLevelDomain(NULL, NULL, NULL);) 2025.10.23 23:50:29.640797 [ 30720 ] {5f2cb0d0-619b-4f33-865d-e2fcea554917} TCPHandler: Code: 42. DB::Exception: Number of arguments for function topLevelDomain doesn't match: passed 3, should be 1: In scope SELECT topLevelDomain(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:29.662730 [ 30720 ] {e7518bb9-e73b-4d90-b79b-e8b8fb570cc0} executeQuery: Code: 42. DB::Exception: Number of arguments for function topLevelDomainRFC doesn't match: passed 3, should be 1: In scope SELECT topLevelDomainRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT topLevelDomainRFC(NULL, NULL, NULL);) 2025.10.23 23:50:29.665051 [ 30720 ] {e7518bb9-e73b-4d90-b79b-e8b8fb570cc0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function topLevelDomainRFC doesn't match: passed 3, should be 1: In scope SELECT topLevelDomainRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:29.686854 [ 3523 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:29.687251 [ 30720 ] {8c4aa67f-a01e-4b19-ab8f-aeb5151dd5eb} executeQuery: Code: 42. DB::Exception: Number of arguments for function transactionID doesn't match: passed 3, should be 0: In scope SELECT transactionID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT transactionID(NULL, NULL, NULL);) 2025.10.23 23:50:29.689904 [ 30720 ] {8c4aa67f-a01e-4b19-ab8f-aeb5151dd5eb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function transactionID doesn't match: passed 3, should be 0: In scope SELECT transactionID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:29.703654 [ 3511 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:29.710621 [ 30720 ] {594b58a0-ffcc-4cfd-9c4e-bf929e905269} executeQuery: Code: 42. DB::Exception: Number of arguments for function transactionLatestSnapshot doesn't match: passed 3, should be 0: In scope SELECT transactionLatestSnapshot(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT transactionLatestSnapshot(NULL, NULL, NULL);) 2025.10.23 23:50:29.714388 [ 30720 ] {594b58a0-ffcc-4cfd-9c4e-bf929e905269} TCPHandler: Code: 42. DB::Exception: Number of arguments for function transactionLatestSnapshot doesn't match: passed 3, should be 0: In scope SELECT transactionLatestSnapshot(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:29.824781 [ 30720 ] {46e3ebc7-5e96-4f11-b46c-bb6423052b1e} executeQuery: Code: 42. DB::Exception: Number of arguments for function transactionOldestSnapshot doesn't match: passed 3, should be 0: In scope SELECT transactionOldestSnapshot(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT transactionOldestSnapshot(NULL, NULL, NULL);) 2025.10.23 23:50:29.838155 [ 3518 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:29.873685 [ 30720 ] {46e3ebc7-5e96-4f11-b46c-bb6423052b1e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function transactionOldestSnapshot doesn't match: passed 3, should be 0: In scope SELECT transactionOldestSnapshot(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:30.069780 [ 3510 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:30.169865 [ 30720 ] {2fa30546-3c67-43e7-ad17-cb7266f7b800} executeQuery: Code: 43. DB::Exception: Second argument of function transform, must be array of source values to transform from.: In scope SELECT transform(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT transform(NULL, NULL, NULL);) 2025.10.23 23:50:30.174050 [ 30720 ] {2fa30546-3c67-43e7-ad17-cb7266f7b800} TCPHandler: Code: 43. DB::Exception: Second argument of function transform, must be array of source values to transform from.: In scope SELECT transform(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:50:30.441160 [ 30720 ] {0269dd6c-21d6-40bf-b154-60a8f9b60285} executeQuery: Code: 42. DB::Exception: Number of arguments for function trimBoth doesn't match: passed 3, should be 1: In scope SELECT trimBoth(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT trimBoth(NULL, NULL, NULL);) 2025.10.23 23:50:30.446147 [ 30720 ] {0269dd6c-21d6-40bf-b154-60a8f9b60285} TCPHandler: Code: 42. DB::Exception: Number of arguments for function trimBoth doesn't match: passed 3, should be 1: In scope SELECT trimBoth(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:30.492979 [ 30720 ] {0283196f-509c-45aa-8845-dfacf9150a62} executeQuery: Code: 42. DB::Exception: Number of arguments for function trimLeft doesn't match: passed 3, should be 1: In scope SELECT trimLeft(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT trimLeft(NULL, NULL, NULL);) 2025.10.23 23:50:30.496938 [ 30720 ] {0283196f-509c-45aa-8845-dfacf9150a62} TCPHandler: Code: 42. DB::Exception: Number of arguments for function trimLeft doesn't match: passed 3, should be 1: In scope SELECT trimLeft(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:30.524796 [ 30720 ] {25575331-4ab3-4957-9d88-7f05f40052ae} executeQuery: Code: 42. DB::Exception: Number of arguments for function trimRight doesn't match: passed 3, should be 1: In scope SELECT trimRight(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT trimRight(NULL, NULL, NULL);) 2025.10.23 23:50:30.528585 [ 30720 ] {25575331-4ab3-4957-9d88-7f05f40052ae} TCPHandler: Code: 42. DB::Exception: Number of arguments for function trimRight doesn't match: passed 3, should be 1: In scope SELECT trimRight(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:30.538602 [ 3507 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:30.584456 [ 3520 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:30.688244 [ 3497 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:30.704963 [ 3496 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:30.741084 [ 30720 ] {c7c9f629-f0e9-4f61-888d-89020165c5c9} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryBase58Decode doesn't match: passed 3, should be 1: In scope SELECT tryBase58Decode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tryBase58Decode(NULL, NULL, NULL);) 2025.10.23 23:50:30.761517 [ 30720 ] {c7c9f629-f0e9-4f61-888d-89020165c5c9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryBase58Decode doesn't match: passed 3, should be 1: In scope SELECT tryBase58Decode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:30.782302 [ 30720 ] {6557b320-4235-427a-9ed8-7a5c75891805} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryBase64Decode doesn't match: passed 3, should be 1: In scope SELECT tryBase64Decode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tryBase64Decode(NULL, NULL, NULL);) 2025.10.23 23:50:30.785530 [ 30720 ] {6557b320-4235-427a-9ed8-7a5c75891805} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryBase64Decode doesn't match: passed 3, should be 1: In scope SELECT tryBase64Decode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:30.807479 [ 30720 ] {e05cbcb0-cf99-4638-b51c-59d3bb56438e} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryBase64URLDecode doesn't match: passed 3, should be 1: In scope SELECT tryBase64URLDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tryBase64URLDecode(NULL, NULL, NULL);) 2025.10.23 23:50:30.812760 [ 30720 ] {e05cbcb0-cf99-4638-b51c-59d3bb56438e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryBase64URLDecode doesn't match: passed 3, should be 1: In scope SELECT tryBase64URLDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:30.839450 [ 3488 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:30.876670 [ 30720 ] {83dd8012-b6f4-4c0a-aa05-2c67cf3fa937} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryIdnaEncode doesn't match: passed 3, should be 1: In scope SELECT tryIdnaEncode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tryIdnaEncode(NULL, NULL, NULL);) 2025.10.23 23:50:30.879748 [ 30720 ] {83dd8012-b6f4-4c0a-aa05-2c67cf3fa937} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryIdnaEncode doesn't match: passed 3, should be 1: In scope SELECT tryIdnaEncode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:30.902902 [ 30720 ] {7a3740e1-5fe3-4196-8c3a-72b221a412ea} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryPunycodeDecode doesn't match: passed 3, should be 1: In scope SELECT tryPunycodeDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tryPunycodeDecode(NULL, NULL, NULL);) 2025.10.23 23:50:30.905990 [ 30720 ] {7a3740e1-5fe3-4196-8c3a-72b221a412ea} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryPunycodeDecode doesn't match: passed 3, should be 1: In scope SELECT tryPunycodeDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:31.071359 [ 3479 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:31.539734 [ 3485 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:31.569892 [ 30720 ] {9eddb4ed-5cbc-4272-8187-bc1750ba5094} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleDivide doesn't match: passed 3, should be 2: In scope SELECT tupleDivide(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tupleDivide(NULL, NULL, NULL);) 2025.10.23 23:50:31.572961 [ 30720 ] {9eddb4ed-5cbc-4272-8187-bc1750ba5094} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleDivide doesn't match: passed 3, should be 2: In scope SELECT tupleDivide(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:31.585569 [ 3487 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:31.590723 [ 30720 ] {02f5d1e5-dc29-4371-a833-3d78ded2b5c5} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleDivideByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleDivideByNumber(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tupleDivideByNumber(NULL, NULL, NULL);) 2025.10.23 23:50:31.593224 [ 30720 ] {02f5d1e5-dc29-4371-a833-3d78ded2b5c5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleDivideByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleDivideByNumber(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:31.645469 [ 30720 ] {cfdaad3f-f599-4e73-8217-2831f76e4927} executeQuery: Code: 43. DB::Exception: First argument for function tupleElement must be tuple or array of tuple. Actual Nullable(Nothing): In scope SELECT tupleElement(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tupleElement(NULL, NULL, NULL);) 2025.10.23 23:50:31.648543 [ 30720 ] {cfdaad3f-f599-4e73-8217-2831f76e4927} TCPHandler: Code: 43. DB::Exception: First argument for function tupleElement must be tuple or array of tuple. Actual Nullable(Nothing): In scope SELECT tupleElement(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:50:31.669128 [ 30720 ] {d94410fb-d7a6-45a3-bdbb-47b8e28f3a5c} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleHammingDistance doesn't match: passed 3, should be 2: In scope SELECT tupleHammingDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tupleHammingDistance(NULL, NULL, NULL);) 2025.10.23 23:50:31.673009 [ 30720 ] {d94410fb-d7a6-45a3-bdbb-47b8e28f3a5c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleHammingDistance doesn't match: passed 3, should be 2: In scope SELECT tupleHammingDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:31.689254 [ 3468 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:31.690442 [ 30720 ] {6cb46792-fa4a-4645-a45a-f200372d974f} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleIntDiv doesn't match: passed 3, should be 2: In scope SELECT tupleIntDiv(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tupleIntDiv(NULL, NULL, NULL);) 2025.10.23 23:50:31.693018 [ 30720 ] {6cb46792-fa4a-4645-a45a-f200372d974f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleIntDiv doesn't match: passed 3, should be 2: In scope SELECT tupleIntDiv(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:31.706228 [ 3461 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:31.711172 [ 30720 ] {e2365afe-d3d6-4b20-ae03-16c724d73ca1} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleIntDivByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleIntDivByNumber(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tupleIntDivByNumber(NULL, NULL, NULL);) 2025.10.23 23:50:31.714255 [ 30720 ] {e2365afe-d3d6-4b20-ae03-16c724d73ca1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleIntDivByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleIntDivByNumber(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:31.823402 [ 30720 ] {2b1b27cd-1599-424d-8685-4fe6884abfe1} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleIntDivOrZero doesn't match: passed 3, should be 2: In scope SELECT tupleIntDivOrZero(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tupleIntDivOrZero(NULL, NULL, NULL);) 2025.10.23 23:50:31.840734 [ 3457 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:31.916300 [ 30720 ] {2b1b27cd-1599-424d-8685-4fe6884abfe1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleIntDivOrZero doesn't match: passed 3, should be 2: In scope SELECT tupleIntDivOrZero(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:31.943994 [ 30720 ] {291a92e3-fda4-49fa-9a8c-28e6a846578d} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleIntDivOrZeroByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleIntDivOrZeroByNumber(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tupleIntDivOrZeroByNumber(NULL, NULL, NULL);) 2025.10.23 23:50:31.947684 [ 30720 ] {291a92e3-fda4-49fa-9a8c-28e6a846578d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleIntDivOrZeroByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleIntDivOrZeroByNumber(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:32.057262 [ 30720 ] {9ae17a54-16c5-4369-b02b-b9912d04e27f} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleMinus doesn't match: passed 3, should be 2: In scope SELECT tupleMinus(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tupleMinus(NULL, NULL, NULL);) 2025.10.23 23:50:32.062137 [ 30720 ] {9ae17a54-16c5-4369-b02b-b9912d04e27f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleMinus doesn't match: passed 3, should be 2: In scope SELECT tupleMinus(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:32.072922 [ 3462 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:32.090820 [ 30720 ] {0c720c34-bb7f-45b1-9a1c-d67c63e2670f} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleModulo doesn't match: passed 3, should be 2: In scope SELECT tupleModulo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tupleModulo(NULL, NULL, NULL);) 2025.10.23 23:50:32.095113 [ 30720 ] {0c720c34-bb7f-45b1-9a1c-d67c63e2670f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleModulo doesn't match: passed 3, should be 2: In scope SELECT tupleModulo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:32.122950 [ 30720 ] {5fd7f4d3-8d36-4329-bd6a-71b43e0c9c73} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleModuloByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleModuloByNumber(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tupleModuloByNumber(NULL, NULL, NULL);) 2025.10.23 23:50:32.127173 [ 30720 ] {5fd7f4d3-8d36-4329-bd6a-71b43e0c9c73} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleModuloByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleModuloByNumber(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:32.155178 [ 30720 ] {0d5a2d9a-4ed1-4111-85de-887adf072097} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleMultiply doesn't match: passed 3, should be 2: In scope SELECT tupleMultiply(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tupleMultiply(NULL, NULL, NULL);) 2025.10.23 23:50:32.159098 [ 30720 ] {0d5a2d9a-4ed1-4111-85de-887adf072097} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleMultiply doesn't match: passed 3, should be 2: In scope SELECT tupleMultiply(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:32.185890 [ 30720 ] {c4dd230d-a760-48f1-b436-063589fe6aaa} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleMultiplyByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleMultiplyByNumber(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tupleMultiplyByNumber(NULL, NULL, NULL);) 2025.10.23 23:50:32.189749 [ 30720 ] {c4dd230d-a760-48f1-b436-063589fe6aaa} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleMultiplyByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleMultiplyByNumber(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:32.217074 [ 30720 ] {aeb95ef0-dc6f-438e-92d3-2ccfdfb4954c} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleNames doesn't match: passed 3, should be 1: In scope SELECT tupleNames(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tupleNames(NULL, NULL, NULL);) 2025.10.23 23:50:32.220868 [ 30720 ] {aeb95ef0-dc6f-438e-92d3-2ccfdfb4954c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleNames doesn't match: passed 3, should be 1: In scope SELECT tupleNames(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:32.247984 [ 30720 ] {050c6289-f65a-43f3-832b-4d737f087834} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleNegate doesn't match: passed 3, should be 1: In scope SELECT tupleNegate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tupleNegate(NULL, NULL, NULL);) 2025.10.23 23:50:32.251084 [ 30720 ] {050c6289-f65a-43f3-832b-4d737f087834} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleNegate doesn't match: passed 3, should be 1: In scope SELECT tupleNegate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:32.362093 [ 4841 ] {7bc44dfc-ef76-4026-9c82-e0b95e68ec8a} executeQuery: Code: 41. DB::Exception: Cannot read DateTime: unexpected word: while executing 'FUNCTION toWeek(__table1.invalid :: 1) -> toWeek(__table1.invalid) UInt8 : 0'. (CANNOT_PARSE_DATETIME) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:47708) (comment: 01661_week_functions_string_args.sql) (in query: SELECT toWeek(invalid) FROM `tab`;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:99: auto void DB::(anonymous namespace)::parseDateTimeBestEffortImpl(long&, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&, DB::(anonymous namespace)::DateTimeSubsecondPart*, char const*)::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000020272ad4 5. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:0: DB::parseDateTime64BestEffort(DB::DateTime64&, unsigned int, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&) @ 0x0000000020245464 6. COW::immutable_ptr DB::CustomWeekTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToWeekImpl) @ 0x000000001c5ae681 7. DB::FunctionCustomWeekToSomething, DB::ToWeekImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c5a8902 8. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d57db 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffeaa 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a24ade 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b82c484 14. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acdc84 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae66ecb 16. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 21. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 2025.10.23 23:50:32.366378 [ 4841 ] {7bc44dfc-ef76-4026-9c82-e0b95e68ec8a} TCPHandler: Code: 41. DB::Exception: Cannot read DateTime: unexpected word: while executing 'FUNCTION toWeek(__table1.invalid :: 1) -> toWeek(__table1.invalid) UInt8 : 0'. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:99: auto void DB::(anonymous namespace)::parseDateTimeBestEffortImpl(long&, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&, DB::(anonymous namespace)::DateTimeSubsecondPart*, char const*)::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000020272ad4 5. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:0: DB::parseDateTime64BestEffort(DB::DateTime64&, unsigned int, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&) @ 0x0000000020245464 6. COW::immutable_ptr DB::CustomWeekTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToWeekImpl) @ 0x000000001c5ae681 7. DB::FunctionCustomWeekToSomething, DB::ToWeekImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c5a8902 8. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d57db 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffeaa 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a24ade 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b82c484 14. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acdc84 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae66ecb 16. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 21. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 2025.10.23 23:50:32.401054 [ 30720 ] {fffeeba8-ef4f-4ec7-bb61-410afc8bb4dc} executeQuery: Code: 42. DB::Exception: Number of arguments for function tuplePlus doesn't match: passed 3, should be 2: In scope SELECT tuplePlus(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tuplePlus(NULL, NULL, NULL);) 2025.10.23 23:50:32.403589 [ 30720 ] {fffeeba8-ef4f-4ec7-bb61-410afc8bb4dc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tuplePlus doesn't match: passed 3, should be 2: In scope SELECT tuplePlus(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:32.426028 [ 30720 ] {9cbd8c11-52d5-4bf4-bfab-7443010c0570} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleToNameValuePairs doesn't match: passed 3, should be 1: In scope SELECT tupleToNameValuePairs(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tupleToNameValuePairs(NULL, NULL, NULL);) 2025.10.23 23:50:32.428906 [ 30720 ] {9cbd8c11-52d5-4bf4-bfab-7443010c0570} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleToNameValuePairs doesn't match: passed 3, should be 1: In scope SELECT tupleToNameValuePairs(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:32.540836 [ 3449 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:32.586497 [ 3442 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:32.637812 [ 30720 ] {14827f26-cde0-4f06-8a89-dff902d4db8e} executeQuery: Code: 42. DB::Exception: Number of arguments for function upper doesn't match: passed 3, should be 1: In scope SELECT ucase(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT ucase(NULL, NULL, NULL);) 2025.10.23 23:50:32.685662 [ 30720 ] {14827f26-cde0-4f06-8a89-dff902d4db8e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function upper doesn't match: passed 3, should be 1: In scope SELECT ucase(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:32.690390 [ 3431 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:32.707559 [ 3423 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:32.761151 [ 30720 ] {cd1ba33a-4ef2-4197-8af2-feb7da40a91f} executeQuery: Code: 42. DB::Exception: Number of arguments for function unbin doesn't match: passed 3, should be 1: In scope SELECT unbin(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT unbin(NULL, NULL, NULL);) 2025.10.23 23:50:32.764175 [ 30720 ] {cd1ba33a-4ef2-4197-8af2-feb7da40a91f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function unbin doesn't match: passed 3, should be 1: In scope SELECT unbin(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:32.842049 [ 3533 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:32.932335 [ 30720 ] {05648c60-9b25-4361-b0d0-4bda500775e5} executeQuery: Code: 42. DB::Exception: Number of arguments for function unhex doesn't match: passed 3, should be 1: In scope SELECT unhex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT unhex(NULL, NULL, NULL);) 2025.10.23 23:50:32.936481 [ 30720 ] {05648c60-9b25-4361-b0d0-4bda500775e5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function unhex doesn't match: passed 3, should be 1: In scope SELECT unhex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:33.074344 [ 3428 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:33.542019 [ 3412 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:33.621317 [ 30720 ] {8cf13dba-725b-4af2-93fb-350ff167ef1e} executeQuery: Code: 42. DB::Exception: Number of arguments for function uniqThetaIntersect doesn't match: passed 3, should be 2: In scope SELECT uniqThetaIntersect(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT uniqThetaIntersect(NULL, NULL, NULL);) 2025.10.23 23:50:33.624738 [ 30720 ] {8cf13dba-725b-4af2-93fb-350ff167ef1e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function uniqThetaIntersect doesn't match: passed 3, should be 2: In scope SELECT uniqThetaIntersect(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:33.647995 [ 30720 ] {6852818b-4311-404b-b9c3-a21e8f8dd3e2} executeQuery: Code: 42. DB::Exception: Number of arguments for function uniqThetaNot doesn't match: passed 3, should be 2: In scope SELECT uniqThetaNot(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT uniqThetaNot(NULL, NULL, NULL);) 2025.10.23 23:50:33.651426 [ 30720 ] {6852818b-4311-404b-b9c3-a21e8f8dd3e2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function uniqThetaNot doesn't match: passed 3, should be 2: In scope SELECT uniqThetaNot(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:33.587604 [ 3407 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:33.674358 [ 30720 ] {df1b3f6b-75f5-46df-ba1f-2456b89dc67d} executeQuery: Code: 42. DB::Exception: Number of arguments for function uniqThetaUnion doesn't match: passed 3, should be 2: In scope SELECT uniqThetaUnion(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT uniqThetaUnion(NULL, NULL, NULL);) 2025.10.23 23:50:33.677736 [ 30720 ] {df1b3f6b-75f5-46df-ba1f-2456b89dc67d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function uniqThetaUnion doesn't match: passed 3, should be 2: In scope SELECT uniqThetaUnion(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:33.691511 [ 3393 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:33.709157 [ 3405 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:33.811630 [ 30720 ] {10a60dae-d6e0-4893-ad6a-2f9151cb6d6b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT uniqUpTo(NULL, NULL, NULL);) 2025.10.23 23:50:33.815614 [ 30720 ] {10a60dae-d6e0-4893-ad6a-2f9151cb6d6b} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) 2025.10.23 23:50:33.843122 [ 3399 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:33.895954 [ 30720 ] {4a3bb3c4-8f04-4ee9-b6c5-7f03ea22ddcf} executeQuery: Code: 42. DB::Exception: Number of arguments for function upper doesn't match: passed 3, should be 1: In scope SELECT upper(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT upper(NULL, NULL, NULL);) 2025.10.23 23:50:33.898894 [ 30720 ] {4a3bb3c4-8f04-4ee9-b6c5-7f03ea22ddcf} TCPHandler: Code: 42. DB::Exception: Number of arguments for function upper doesn't match: passed 3, should be 1: In scope SELECT upper(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:33.922543 [ 30720 ] {7bbf5431-82e2-4abc-9f34-4d229ca5ebe5} executeQuery: Code: 42. DB::Exception: Number of arguments for function upperUTF8 doesn't match: passed 3, should be 1: In scope SELECT upperUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT upperUTF8(NULL, NULL, NULL);) 2025.10.23 23:50:33.925490 [ 30720 ] {7bbf5431-82e2-4abc-9f34-4d229ca5ebe5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function upperUTF8 doesn't match: passed 3, should be 1: In scope SELECT upperUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:33.948705 [ 30720 ] {9efc84d6-7d6e-4d31-9121-239ceb7e4c09} executeQuery: Code: 42. DB::Exception: Number of arguments for function uptime doesn't match: passed 3, should be 0: In scope SELECT uptime(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT uptime(NULL, NULL, NULL);) 2025.10.23 23:50:33.952515 [ 30720 ] {9efc84d6-7d6e-4d31-9121-239ceb7e4c09} TCPHandler: Code: 42. DB::Exception: Number of arguments for function uptime doesn't match: passed 3, should be 0: In scope SELECT uptime(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:33.977174 [ 30720 ] {ed55c5ec-6a97-4bd4-a24b-9e3f474b25db} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 3, should be 0: In scope SELECT user(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT user(NULL, NULL, NULL);) 2025.10.23 23:50:33.980783 [ 30720 ] {ed55c5ec-6a97-4bd4-a24b-9e3f474b25db} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 3, should be 0: In scope SELECT user(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:34.076671 [ 3474 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:34.543119 [ 3439 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:34.652930 [ 3367 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:34.668912 [ 30720 ] {7c2f4132-ded2-4f2f-bd90-734125a15cb4} executeQuery: Code: 43. DB::Exception: First argument for function variantElement must be Variant or Array of Variant. Actual Nullable(Nothing): In scope SELECT variantElement(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT variantElement(NULL, NULL, NULL);) 2025.10.23 23:50:34.673487 [ 30720 ] {7c2f4132-ded2-4f2f-bd90-734125a15cb4} TCPHandler: Code: 43. DB::Exception: First argument for function variantElement must be Variant or Array of Variant. Actual Nullable(Nothing): In scope SELECT variantElement(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:50:34.692922 [ 3381 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:34.710253 [ 3383 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:34.764579 [ 30720 ] {854d514b-7f1a-48db-8906-771f42e6969e} executeQuery: Code: 42. DB::Exception: Number of arguments for function variantType doesn't match: passed 3, should be 1: In scope SELECT variantType(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT variantType(NULL, NULL, NULL);) 2025.10.23 23:50:34.769064 [ 30720 ] {854d514b-7f1a-48db-8906-771f42e6969e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function variantType doesn't match: passed 3, should be 1: In scope SELECT variantType(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:34.844885 [ 3376 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:34.867544 [ 30720 ] {eeec541b-9974-4ead-8bd9-0ead8f0eb269} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleMinus doesn't match: passed 3, should be 2: In scope SELECT vectorDifference(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT vectorDifference(NULL, NULL, NULL);) 2025.10.23 23:50:34.871201 [ 30720 ] {eeec541b-9974-4ead-8bd9-0ead8f0eb269} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleMinus doesn't match: passed 3, should be 2: In scope SELECT vectorDifference(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:34.950270 [ 30720 ] {6e243b55-4878-4e53-9fb2-dee4468cca28} executeQuery: Code: 42. DB::Exception: Number of arguments for function tuplePlus doesn't match: passed 3, should be 2: In scope SELECT vectorSum(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT vectorSum(NULL, NULL, NULL);) 2025.10.23 23:50:34.958236 [ 30720 ] {6e243b55-4878-4e53-9fb2-dee4468cca28} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tuplePlus doesn't match: passed 3, should be 2: In scope SELECT vectorSum(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:34.984924 [ 30720 ] {a2ad8bfb-0a24-437b-968f-14b0dd6f4979} executeQuery: Code: 42. DB::Exception: Number of arguments for function version doesn't match: passed 3, should be 0: In scope SELECT version(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT version(NULL, NULL, NULL);) 2025.10.23 23:50:34.988548 [ 30720 ] {a2ad8bfb-0a24-437b-968f-14b0dd6f4979} TCPHandler: Code: 42. DB::Exception: Number of arguments for function version doesn't match: passed 3, should be 0: In scope SELECT version(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:35.069236 [ 30720 ] {98683fa6-3875-4c49-9e36-a89961fbe5f7} executeQuery: Code: 42. DB::Exception: Number of arguments for function visibleWidth doesn't match: passed 3, should be 1: In scope SELECT visibleWidth(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT visibleWidth(NULL, NULL, NULL);) 2025.10.23 23:50:35.073577 [ 30720 ] {98683fa6-3875-4c49-9e36-a89961fbe5f7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function visibleWidth doesn't match: passed 3, should be 1: In scope SELECT visibleWidth(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:35.078200 [ 3366 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:35.099310 [ 30720 ] {a40f6e84-0dd7-4b67-8dc0-e19bcd8158e8} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractBool doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractBool(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT visitParamExtractBool(NULL, NULL, NULL);) 2025.10.23 23:50:35.102950 [ 30720 ] {a40f6e84-0dd7-4b67-8dc0-e19bcd8158e8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractBool doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractBool(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:35.126386 [ 30720 ] {371a75cd-cccd-4375-b6ee-fd07394f50af} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractFloat doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractFloat(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT visitParamExtractFloat(NULL, NULL, NULL);) 2025.10.23 23:50:35.129766 [ 30720 ] {371a75cd-cccd-4375-b6ee-fd07394f50af} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractFloat doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractFloat(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:35.247416 [ 4841 ] {123d2b2c-6c8f-4c70-b8f5-63bc09ee167b} executeQuery: Code: 41. DB::Exception: Cannot read DateTime: unexpected word: while executing 'FUNCTION toYearWeek(__table1.invalid :: 1) -> toYearWeek(__table1.invalid) UInt32 : 0'. (CANNOT_PARSE_DATETIME) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:47708) (comment: 01661_week_functions_string_args.sql) (in query: SELECT toYearWeek(invalid) FROM `tab`;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:99: auto void DB::(anonymous namespace)::parseDateTimeBestEffortImpl(long&, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&, DB::(anonymous namespace)::DateTimeSubsecondPart*, char const*)::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000020272ad4 5. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:0: DB::parseDateTime64BestEffort(DB::DateTime64&, unsigned int, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&) @ 0x0000000020245464 6. COW::immutable_ptr DB::CustomWeekTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToYearWeekImpl) @ 0x000000001c5b7bc1 7. DB::FunctionCustomWeekToSomething, DB::ToYearWeekImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c5b2bc2 8. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d57db 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffeaa 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a24ade 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b82c484 14. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acdc84 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae66ecb 16. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 21. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 2025.10.23 23:50:35.292601 [ 30720 ] {fc5a3f15-8a9e-4f13-8bc4-391e8659d9f4} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractInt doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractInt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT visitParamExtractInt(NULL, NULL, NULL);) 2025.10.23 23:50:35.333680 [ 30720 ] {fc5a3f15-8a9e-4f13-8bc4-391e8659d9f4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractInt doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractInt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:35.334022 [ 4841 ] {123d2b2c-6c8f-4c70-b8f5-63bc09ee167b} TCPHandler: Code: 41. DB::Exception: Cannot read DateTime: unexpected word: while executing 'FUNCTION toYearWeek(__table1.invalid :: 1) -> toYearWeek(__table1.invalid) UInt32 : 0'. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:99: auto void DB::(anonymous namespace)::parseDateTimeBestEffortImpl(long&, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&, DB::(anonymous namespace)::DateTimeSubsecondPart*, char const*)::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000020272ad4 5. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:0: DB::parseDateTime64BestEffort(DB::DateTime64&, unsigned int, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&) @ 0x0000000020245464 6. COW::immutable_ptr DB::CustomWeekTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToYearWeekImpl) @ 0x000000001c5b7bc1 7. DB::FunctionCustomWeekToSomething, DB::ToYearWeekImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c5b2bc2 8. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d57db 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffeaa 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a24ade 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b82c484 14. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acdc84 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae66ecb 16. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 21. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 2025.10.23 23:50:35.425698 [ 30720 ] {ce2bba37-cad7-4856-a6d1-31d4ae106b82} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractRaw doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractRaw(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT visitParamExtractRaw(NULL, NULL, NULL);) 2025.10.23 23:50:35.429553 [ 30720 ] {ce2bba37-cad7-4856-a6d1-31d4ae106b82} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractRaw doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractRaw(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:35.544495 [ 3354 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:35.550968 [ 30720 ] {8e5e2119-ecb5-4505-ac14-c7428a62b268} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractString doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT visitParamExtractString(NULL, NULL, NULL);) 2025.10.23 23:50:35.555359 [ 30720 ] {8e5e2119-ecb5-4505-ac14-c7428a62b268} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractString doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:35.587577 [ 30720 ] {01de37d3-25a1-4098-8262-28b75cc9081d} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractUInt doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractUInt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT visitParamExtractUInt(NULL, NULL, NULL);) 2025.10.23 23:50:35.592803 [ 30720 ] {01de37d3-25a1-4098-8262-28b75cc9081d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractUInt doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractUInt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:35.620093 [ 30720 ] {3e2a3010-55f2-4ccb-bbe4-283a92c92184} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONHas doesn't match: passed 3, should be 2: In scope SELECT visitParamHas(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT visitParamHas(NULL, NULL, NULL);) 2025.10.23 23:50:35.624144 [ 30720 ] {3e2a3010-55f2-4ccb-bbe4-283a92c92184} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONHas doesn't match: passed 3, should be 2: In scope SELECT visitParamHas(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:35.653887 [ 3343 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:35.693968 [ 3349 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:35.711168 [ 3337 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:35.777400 [ 30720 ] {0956b563-3410-44f6-b3e2-1f69b3c7dc06} executeQuery: Code: 42. DB::Exception: Number of arguments for function widthBucket doesn't match: passed 3, should be 4: In scope SELECT widthBucket(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT widthBucket(NULL, NULL, NULL);) 2025.10.23 23:50:35.781172 [ 30720 ] {0956b563-3410-44f6-b3e2-1f69b3c7dc06} TCPHandler: Code: 42. DB::Exception: Number of arguments for function widthBucket doesn't match: passed 3, should be 4: In scope SELECT widthBucket(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:35.845954 [ 3347 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:35.897645 [ 30720 ] {d31faf13-7ad7-4793-92a4-e9dcef34c136} executeQuery: Code: 42. DB::Exception: Number of arguments for function widthBucket doesn't match: passed 3, should be 4: In scope SELECT width_bucket(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT width_bucket(NULL, NULL, NULL);) 2025.10.23 23:50:35.901453 [ 30720 ] {d31faf13-7ad7-4793-92a4-e9dcef34c136} TCPHandler: Code: 42. DB::Exception: Number of arguments for function widthBucket doesn't match: passed 3, should be 4: In scope SELECT width_bucket(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:36.079481 [ 3315 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:36.308162 [ 30720 ] {63f991db-3412-44b2-8661-28efcf6ac55b} executeQuery: Code: 42. DB::Exception: Number of arguments for function wkt doesn't match: passed 3, should be 1: In scope SELECT wkt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT wkt(NULL, NULL, NULL);) 2025.10.23 23:50:36.311529 [ 30720 ] {63f991db-3412-44b2-8661-28efcf6ac55b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function wkt doesn't match: passed 3, should be 1: In scope SELECT wkt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:36.545640 [ 3324 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:36.655012 [ 3305 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:36.695256 [ 3358 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:36.712639 [ 3318 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:36.847272 [ 3297 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:37.081018 [ 3317 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:37.546947 [ 3331 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:37.696814 [ 3356 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:37.702491 [ 3311 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:37.713994 [ 3325 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:37.848376 [ 3340 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:37.875095 [ 30720 ] {4f2c01c8-6a32-46da-8e11-490d11db4b61} executeQuery: Code: 42. DB::Exception: Number of arguments for function kostikConsistentHash doesn't match: passed 3, should be 2: In scope SELECT yandexConsistentHash(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT yandexConsistentHash(NULL, NULL, NULL);) 2025.10.23 23:50:37.878890 [ 30720 ] {4f2c01c8-6a32-46da-8e11-490d11db4b61} TCPHandler: Code: 42. DB::Exception: Number of arguments for function kostikConsistentHash doesn't match: passed 3, should be 2: In scope SELECT yandexConsistentHash(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:38.039393 [ 30720 ] {e7f35995-b2bc-4791-910b-6df2b7fde78c} executeQuery: Code: 42. DB::Exception: Number of arguments for function yesterday doesn't match: passed 3, should be 0: In scope SELECT yesterday(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT yesterday(NULL, NULL, NULL);) 2025.10.23 23:50:38.043266 [ 30720 ] {e7f35995-b2bc-4791-910b-6df2b7fde78c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function yesterday doesn't match: passed 3, should be 0: In scope SELECT yesterday(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:38.071246 [ 30720 ] {31d0716a-f4be-4da9-a887-7e616d661f9c} executeQuery: Code: 42. DB::Exception: Number of arguments for function zookeeperSessionUptime doesn't match: passed 3, should be 0: In scope SELECT zookeeperSessionUptime(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42634) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT zookeeperSessionUptime(NULL, NULL, NULL);) 2025.10.23 23:50:38.074858 [ 30720 ] {31d0716a-f4be-4da9-a887-7e616d661f9c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function zookeeperSessionUptime doesn't match: passed 3, should be 0: In scope SELECT zookeeperSessionUptime(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:50:38.082775 [ 3299 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:38.183192 [ 4799 ] {de6b0861-4963-44c4-ae90-a0c183020dce} executeQuery: Code: 47. DB::Exception: Missing columns: 'String' while processing query: 'String AS b', required columns: 'String' 'String': default expression and column type are incompatible. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:45178) (comment: 02287_ephemeral_format_crash.sql) (in query: CREATE TABLE test(a UInt8, b EPHEMERAL 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1280: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x0000000035631abf 4. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1536: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x0000000035653c9d 5. ./build_docker/./src/Storages/ColumnsDescription.cpp:985: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000380ff889 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000348a82f8 7. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348af396 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cde07 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:50:38.185829 [ 4799 ] {de6b0861-4963-44c4-ae90-a0c183020dce} TCPHandler: Code: 47. DB::Exception: Missing columns: 'String' while processing query: 'String AS b', required columns: 'String' 'String': default expression and column type are incompatible. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1280: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x0000000035631abf 4. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1536: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x0000000035653c9d 5. ./build_docker/./src/Storages/ColumnsDescription.cpp:985: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000380ff889 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000348a82f8 7. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348af396 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cde07 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:50:38.314490 [ 4799 ] {cdacd82a-0604-4d59-9dff-ff388ae7e75f} executeQuery: Code: 47. DB::Exception: Missing columns: 'test' while processing query: '_CAST(test AS b_tmp_alter2021551295478025500, 'String') AS b, b_tmp_alter2021551295478025500', required columns: 'test' 'test': default expression and column type are incompatible. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:45178) (comment: 02287_ephemeral_format_crash.sql) (in query: CREATE TABLE test(a UInt8, b String EPHEMERAL test) 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1280: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x0000000035631abf 4. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1536: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x0000000035653c9d 5. ./build_docker/./src/Storages/ColumnsDescription.cpp:985: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000380ff889 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000348a82f8 7. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348af396 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cde07 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:50:38.316823 [ 4799 ] {cdacd82a-0604-4d59-9dff-ff388ae7e75f} TCPHandler: Code: 47. DB::Exception: Missing columns: 'test' while processing query: '_CAST(test AS b_tmp_alter2021551295478025500, 'String') AS b, b_tmp_alter2021551295478025500', required columns: 'test' 'test': default expression and column type are incompatible. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1280: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x0000000035631abf 4. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1536: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x0000000035653c9d 5. ./build_docker/./src/Storages/ColumnsDescription.cpp:985: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000380ff889 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000348a82f8 7. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348af396 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cde07 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:50:38.547863 [ 3261 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:38.697887 [ 3263 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:38.703505 [ 3255 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:38.715127 [ 3260 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:38.849259 [ 3246 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:39.084164 [ 3259 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:39.548641 [ 3247 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:39.698786 [ 3232 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:39.704362 [ 3235 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:39.716208 [ 3234 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:39.850470 [ 3230 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:40.085401 [ 3221 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:40.549449 [ 3189 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:40.699829 [ 3186 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:40.705101 [ 3184 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:40.717398 [ 3181 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:40.852086 [ 3192 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:41.086548 [ 3178 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:41.550314 [ 3153 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:41.700892 [ 3150 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:41.706209 [ 3133 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:41.718434 [ 3517 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:41.853207 [ 3144 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:42.087657 [ 3149 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:42.551491 [ 3119 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:42.702201 [ 3140 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:42.707481 [ 3120 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:42.719596 [ 3130 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:42.854349 [ 3131 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:43.089016 [ 3103 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:43.552905 [ 3083 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:43.703469 [ 3082 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:43.708767 [ 3088 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:43.721046 [ 3096 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:43.855379 [ 3090 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:44.090125 [ 3105 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:44.499996 [ 3894 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x00000000315a10ad 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159da2f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b6b4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa269fb 10. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:44.554209 [ 3069 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:44.705045 [ 3060 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:44.709775 [ 3073 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:44.722392 [ 3067 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:44.856220 [ 3427 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:44.866145 [ 2903 ] {9968b84a-3e01-4af3-91be-5ff7fd3c0567} executeQuery: Code: 48. DB::Exception: MergeJoinAlgorithm is not implemented for strictness Semi. (NOT_IMPLEMENTED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:45228) (comment: 01582_any_join_supertype.sql) (in query: SELECT toDateTime(foo.server_time, 'UTC') FROM foo SEMI JOIN bar USING (dimension_1) WHERE toDate(foo.server_time, 'UTC') <= toDate('2020-04-30');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::JoinStrictness&) @ 0x000000003b89536a 4. ./build_docker/./src/Processors/Transforms/MergeJoinTransform.cpp:0: DB::MergeJoinAlgorithm::MergeJoinAlgorithm(DB::JoinKind, DB::JoinStrictness, DB::TableJoin::JoinOnClause const&, std::vector> const&, unsigned long) @ 0x000000003b8732da 5. ./build_docker/./src/Processors/Transforms/MergeJoinTransform.cpp:0: DB::MergeJoinAlgorithm::MergeJoinAlgorithm(std::shared_ptr, std::vector> const&, unsigned long) @ 0x000000003b873fd2 6. ./src/Processors/Merges/IMergingTransform.h:166: DB::MergeJoinTransform::MergeJoinTransform(std::shared_ptr, std::vector> const&, DB::Block const&, unsigned long, unsigned long) @ 0x000000003b8934b1 7. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr&, std::vector>&, DB::Block const&, unsigned long&, void>(std::allocator const&, std::shared_ptr&, std::vector>&, DB::Block const&, unsigned long&) @ 0x00000000322b732f 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::QueryPipelineBuilder::joinPipelinesYShaped(std::unique_ptr>, std::unique_ptr>, std::shared_ptr, DB::Block const&, unsigned long, std::vector, std::allocator>>*) @ 0x000000003229c5d4 9. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:60: DB::JoinStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be7373e 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003beb6da5 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034cf5e6d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034cf5881 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 22. ? @ 0x00007f100c857ac3 23. ? @ 0x00007f100c8e9850 2025.10.23 23:50:44.869766 [ 2903 ] {9968b84a-3e01-4af3-91be-5ff7fd3c0567} TCPHandler: Code: 48. DB::Exception: MergeJoinAlgorithm is not implemented for strictness Semi. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::JoinStrictness&) @ 0x000000003b89536a 4. ./build_docker/./src/Processors/Transforms/MergeJoinTransform.cpp:0: DB::MergeJoinAlgorithm::MergeJoinAlgorithm(DB::JoinKind, DB::JoinStrictness, DB::TableJoin::JoinOnClause const&, std::vector> const&, unsigned long) @ 0x000000003b8732da 5. ./build_docker/./src/Processors/Transforms/MergeJoinTransform.cpp:0: DB::MergeJoinAlgorithm::MergeJoinAlgorithm(std::shared_ptr, std::vector> const&, unsigned long) @ 0x000000003b873fd2 6. ./src/Processors/Merges/IMergingTransform.h:166: DB::MergeJoinTransform::MergeJoinTransform(std::shared_ptr, std::vector> const&, DB::Block const&, unsigned long, unsigned long) @ 0x000000003b8934b1 7. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr&, std::vector>&, DB::Block const&, unsigned long&, void>(std::allocator const&, std::shared_ptr&, std::vector>&, DB::Block const&, unsigned long&) @ 0x00000000322b732f 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::QueryPipelineBuilder::joinPipelinesYShaped(std::unique_ptr>, std::unique_ptr>, std::shared_ptr, DB::Block const&, unsigned long, std::vector, std::allocator>>*) @ 0x000000003229c5d4 9. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:60: DB::JoinStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be7373e 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003beb6da5 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034cf5e6d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034cf5881 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 22. ? @ 0x00007f100c857ac3 23. ? @ 0x00007f100c8e9850 2025.10.23 23:50:44.880498 [ 3894 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x00000000315a10ad 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159da2f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b6b4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa269fb 10. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:44.929067 [ 4799 ] {018e1ef0-bd5c-4a48-a9c2-9435a21630cc} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:45244) (comment: 03321_functions_to_subcolumns_skip_index.sql) (in query: SELECT * -- 'm' in projection columns FROM bloom_filter_test WHERE mapContains(m, '1') ORDER BY id;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 9. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexReader.cpp:0: DB::MergeTreeIndexReader::MergeTreeIndexReader(std::shared_ptr, std::shared_ptr, unsigned long, DB::MarkRanges const&, DB::MarkCache*, DB::UncompressedCache*, DB::MergeTreeReaderSettings) @ 0x0000000039ad1524 10. ./contrib/llvm-project/libcxx/include/deque:1188: DB::MergeTreeDataSelectExecutor::filterMarksUsingIndex(std::shared_ptr, std::shared_ptr, std::shared_ptr, DB::MarkRanges const&, DB::Settings const&, DB::MergeTreeReaderSettings const&, DB::MarkCache*, DB::UncompressedCache*, std::shared_ptr) @ 0x0000000039a6b082 11. ./contrib/llvm-project/libcxx/include/deque:1730: 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 @ 0x0000000039a650bb 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) @ 0x0000000039a5d60b 13. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003bf2b229 14. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bf26bba 15. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003bf26345 16. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bf3d5b9 17. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2045: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf42fe0 18. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be48783 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003beb6da5 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034cf5e6d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034cf5881 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 31. ? @ 0x00007f100c857ac3 2025.10.23 23:50:44.932585 [ 4799 ] {018e1ef0-bd5c-4a48-a9c2-9435a21630cc} TCPHandler: 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 9. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexReader.cpp:0: DB::MergeTreeIndexReader::MergeTreeIndexReader(std::shared_ptr, std::shared_ptr, unsigned long, DB::MarkRanges const&, DB::MarkCache*, DB::UncompressedCache*, DB::MergeTreeReaderSettings) @ 0x0000000039ad1524 10. ./contrib/llvm-project/libcxx/include/deque:1188: DB::MergeTreeDataSelectExecutor::filterMarksUsingIndex(std::shared_ptr, std::shared_ptr, std::shared_ptr, DB::MarkRanges const&, DB::Settings const&, DB::MergeTreeReaderSettings const&, DB::MarkCache*, DB::UncompressedCache*, std::shared_ptr) @ 0x0000000039a6b082 11. ./contrib/llvm-project/libcxx/include/deque:1730: 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 @ 0x0000000039a650bb 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) @ 0x0000000039a5d60b 13. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003bf2b229 14. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bf26bba 15. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003bf26345 16. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bf3d5b9 17. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2045: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf42fe0 18. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be48783 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003beb6da5 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034cf5e6d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034cf5881 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 31. ? @ 0x00007f100c857ac3 2025.10.23 23:50:45.091346 [ 3396 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:45.555512 [ 3071 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:45.706135 [ 3197 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:45.710817 [ 3174 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:45.723902 [ 3329 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:45.857042 [ 3562 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:46.117714 [ 3535 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:46.556458 [ 3493 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:46.707384 [ 3504 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:46.712034 [ 3482 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:46.725284 [ 3494 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:46.858137 [ 3477 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:47.118933 [ 3464 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:47.557571 [ 3425 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:47.708954 [ 3421 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:47.713572 [ 3409 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:47.726805 [ 3407 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:47.859059 [ 3401 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:48.120227 [ 3360 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:48.514289 [ 4841 ] {5e72b4a0-a168-4ba5-8269-a30e948c911e} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=4). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37418) (comment: 01781_token_extractor_buffer_overflow.sql) (in query: SELECT max(id) FROM bloom_filter WHERE hasToken(s, 'abc');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202dea34 6. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039a5dbc5 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003bf2b229 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bf26bba 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003bf26345 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bf3d5b9 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2045: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf42fe0 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be48783 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003beb6da5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034cf5e6d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034cf5881 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:50:48.517444 [ 4841 ] {5e72b4a0-a168-4ba5-8269-a30e948c911e} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202dea34 6. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039a5dbc5 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003bf2b229 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bf26bba 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003bf26345 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bf3d5b9 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2045: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003bf42fe0 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be48783 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003beb6da5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034cf5e6d 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034cf5881 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:50:48.558884 [ 3324 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:48.710306 [ 3304 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:48.714877 [ 3303 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:48.728242 [ 3297 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:48.860023 [ 3301 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:49.121659 [ 3325 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:49.559843 [ 3292 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:49.711401 [ 3285 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:49.716188 [ 3284 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:49.729253 [ 3278 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:49.860873 [ 3310 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:50.123041 [ 3295 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:50.560957 [ 3262 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:50.712588 [ 3282 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:50.717423 [ 3253 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:50.730349 [ 3248 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:50.861620 [ 3259 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:51.124370 [ 3240 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:51.562340 [ 3234 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:51.713751 [ 3214 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:51.718515 [ 3221 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:51.732047 [ 3216 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:51.862689 [ 3211 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:52.126099 [ 3209 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:52.564052 [ 3186 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:52.715161 [ 3188 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:52.719483 [ 3185 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:52.733184 [ 3192 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:52.863846 [ 3172 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:53.127879 [ 3173 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:53.565375 [ 3153 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:53.716907 [ 3150 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:53.721053 [ 3133 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:53.734655 [ 3517 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:53.865129 [ 3134 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:54.129544 [ 3143 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:54.566641 [ 3115 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:54.718149 [ 3116 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:54.722163 [ 3129 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:54.736125 [ 3123 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:54.866276 [ 3120 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:55.130942 [ 3107 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:55.567639 [ 3110 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:55.719237 [ 3094 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:55.723167 [ 3089 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:55.737154 [ 3082 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:55.867259 [ 3076 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:56.132271 [ 3085 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:56.568739 [ 3065 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:56.720576 [ 3066 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:56.724133 [ 3069 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:56.738154 [ 3056 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:56.868212 [ 3444 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:57.106414 [ 4799 ] {f8374c97-99ae-4cfd-9bee-639852647bc1} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, jobs=1): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37412) (comment: 01413_rows_events.sql) (in query: SELECT written_rows FROM system.query_log WHERE current_database = currentDatabase() AND query LIKE 'INSERT INTO /* test 01413, query 1 */ rows_events_test%' AND type = 2 AND event_date >= yesterday() ORDER BY event_time DESC LIMIT 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 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) @ 0x0000000039c89948 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000003999bfb7 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 @ 0x00000000399942f0 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039d46d05 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003bfd70f5 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolParallelReplicas.cpp:201: DB::MergeTreeReadPoolParallelReplicas::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c062f6e 15. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:37: DB::MergeTreeThreadSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003bf806f4 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d3c440 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf89b85 18. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 19. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 25. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 27. ? @ 0x00007f100c857ac3 28. ? @ 0x00007f100c8e9850 2025.10.23 23:50:57.128041 [ 4799 ] {f8374c97-99ae-4cfd-9bee-639852647bc1} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, jobs=1): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 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) @ 0x0000000039c89948 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000003999bfb7 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 @ 0x00000000399942f0 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039d46d05 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003bfd70f5 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolParallelReplicas.cpp:201: DB::MergeTreeReadPoolParallelReplicas::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c062f6e 15. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:37: DB::MergeTreeThreadSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003bf806f4 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d3c440 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf89b85 18. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 19. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 25. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 27. ? @ 0x00007f100c857ac3 28. ? @ 0x00007f100c8e9850 2025.10.23 23:50:57.133408 [ 3319 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:57.569871 [ 3563 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:57.721580 [ 3329 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:57.724872 [ 3406 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:57.739471 [ 3135 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:57.869030 [ 3061 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:58.134412 [ 3201 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:58.570823 [ 3558 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:58.722474 [ 3532 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:58.725622 [ 3554 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:58.740802 [ 3530 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:58.869880 [ 3549 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:59.135333 [ 3521 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:59.433253 [ 4799 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:50:59.572143 [ 3524 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:59.723444 [ 3520 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:59.726507 [ 3507 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:59.741745 [ 3509 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:59.871223 [ 3363 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:00.136387 [ 3493 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:00.573328 [ 3483 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:00.724710 [ 3489 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:00.727609 [ 3512 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:00.742816 [ 3472 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:00.750224 [ 3894 ] {3e61cb98-67e1-4b15-91e7-4219142216c3} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'x' in scope SELECT x FROM system.numbers LIMIT 1. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:54780) (comment: 02899_use_default_format_on_http_exception.sh) (in query: SELECT x FROM system.numbers LIMIT 1; ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000335017e7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003345512b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 18. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 19. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 20. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 26. ? @ 0x00007f100c857ac3 27. ? @ 0x00007f100c8e9850 2025.10.23 23:51:00.754487 [ 3894 ] {3e61cb98-67e1-4b15-91e7-4219142216c3} DynamicQueryHandler: Code: 47. DB::Exception: Unknown expression identifier 'x' in scope SELECT x FROM system.numbers LIMIT 1. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000335017e7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003345512b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 18. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 19. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 20. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 26. ? @ 0x00007f100c857ac3 27. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:00.872571 [ 3485 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:01.055621 [ 4799 ] {1045367c-f10d-460e-a667-09e2fdd93b85} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Null. (NOT_IMPLEMENTED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:60844) (comment: 01270_optimize_skip_unused_shards_low_cardinality.sql) (in query: drop table data_01270;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000002ffc5e67 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003493f2d5 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:51:01.058559 [ 4799 ] {1045367c-f10d-460e-a667-09e2fdd93b85} TCPHandler: Code: 48. DB::Exception: Truncate is not supported by storage Null. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000002ffc5e67 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003493f2d5 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:51:01.137332 [ 3465 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:01.574419 [ 3454 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:01.725863 [ 3453 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:01.728714 [ 3446 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:01.743961 [ 3456 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:01.873794 [ 3442 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:02.079674 [ 3894 ] {9c2c6c82-0c3b-4d81-be1a-57d9bd35d521} executeQuery: Code: 48. DB::Exception: Method write is not supported by storage SystemNumbers. (NOT_IMPLEMENTED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:54790) (comment: 02899_use_default_format_on_http_exception.sh) (in query: INSERT INTO system.numbers Select * from numbers(10); ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::IStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002ffc59e7 4. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:573: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000003ba9ef4f 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000034ba82a1 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000034bab2af 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034bb1a40 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034bbac4c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:51:02.085889 [ 3894 ] {9c2c6c82-0c3b-4d81-be1a-57d9bd35d521} DynamicQueryHandler: Code: 48. DB::Exception: Method write is not supported by storage SystemNumbers. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::IStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002ffc59e7 4. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:573: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000003ba9ef4f 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000034ba82a1 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000034bab2af 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034bb1a40 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034bbac4c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:02.138703 [ 3432 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:02.367079 [ 3894 ] {5ba0ef2e-3cf6-408d-a33a-801cc14ad6f4} executeQuery: Code: 48. DB::Exception: Method write is not supported by storage SystemNumbers. (NOT_IMPLEMENTED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:54806) (comment: 02899_use_default_format_on_http_exception.sh) (in query: INSERT INTO system.numbers Select * from numbers(10); ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::IStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002ffc59e7 4. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:573: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000003ba9ef4f 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000034ba82a1 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000034bab2af 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034bb1a40 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034bbac4c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:51:02.373099 [ 3894 ] {5ba0ef2e-3cf6-408d-a33a-801cc14ad6f4} DynamicQueryHandler: Code: 48. DB::Exception: Method write is not supported by storage SystemNumbers. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::IStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002ffc59e7 4. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:573: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000003ba9ef4f 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000034ba82a1 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000034bab2af 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034bb1a40 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034bbac4c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:02.426398 [ 4841 ] {87804344-8358-4a90-8b3b-883c854202ab} executeQuery: Code: 48. DB::Exception: Method write is not supported by storage SystemNumbers. (NOT_IMPLEMENTED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:54816) (comment: 02899_use_default_format_on_http_exception.sh) (in query: INSERT INTO system.numbers Select * from numbers(10); ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::IStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002ffc59e7 4. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:573: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000003ba9ef4f 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000034ba82a1 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000034bab2af 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034bb1a40 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034bbac4c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:51:02.575534 [ 3410 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:02.727251 [ 3421 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:02.729903 [ 3414 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:02.745091 [ 3409 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:02.874912 [ 3393 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:03.140067 [ 3399 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:03.468694 [ 4841 ] {87804344-8358-4a90-8b3b-883c854202ab} executeQuery: Code: 73. DB::Exception: Unknown format BADFORMAT. (UNKNOWN_FORMAT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Formats/FormatFactory.cpp:46: DB::FormatFactory::getCreators(String const&) const @ 0x000000003ac86bb1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:863: ? @ 0x000000003ac8fd49 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>)::$_1::operator()() const @ 0x00000000358d21c8 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358cac82 8. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 9. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:51:03.470949 [ 4841 ] {87804344-8358-4a90-8b3b-883c854202ab} DynamicQueryHandler: Code: 48. DB::Exception: Method write is not supported by storage SystemNumbers. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::IStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002ffc59e7 4. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:573: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000003ba9ef4f 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000034ba82a1 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000034bab2af 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034bb1a40 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034bbac4c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:03.505238 [ 4841 ] {de43c852-457c-49c1-8e69-82b86299394f} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'x' in scope SELECT x FROM system.numbers LIMIT 1. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:54830) (comment: 02899_use_default_format_on_http_exception.sh) (in query: SELECT x FROM system.numbers LIMIT 1; ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000335017e7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003345512b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 18. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 19. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 20. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 26. ? @ 0x00007f100c857ac3 27. ? @ 0x00007f100c8e9850 2025.10.23 23:51:03.509333 [ 4841 ] {de43c852-457c-49c1-8e69-82b86299394f} DynamicQueryHandler: Code: 47. DB::Exception: Unknown expression identifier 'x' in scope SELECT x FROM system.numbers LIMIT 1. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000335017e7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003345512b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 18. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 19. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 20. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 26. ? @ 0x00007f100c857ac3 27. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:03.551311 [ 4841 ] {899eb543-69bb-40eb-b342-c3696dfc13c4} executeQuery: Code: 48. DB::Exception: Method write is not supported by storage SystemNumbers. (NOT_IMPLEMENTED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:54832) (comment: 02899_use_default_format_on_http_exception.sh) (in query: INSERT INTO system.numbers Select * from numbers(10); ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::IStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002ffc59e7 4. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:573: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000003ba9ef4f 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000034ba82a1 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000034bab2af 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034bb1a40 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034bbac4c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:51:03.576801 [ 3398 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:03.607583 [ 4841 ] {899eb543-69bb-40eb-b342-c3696dfc13c4} DynamicQueryHandler: Code: 48. DB::Exception: Method write is not supported by storage SystemNumbers. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::IStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002ffc59e7 4. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:573: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000003ba9ef4f 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000034ba82a1 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000034bab2af 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034bb1a40 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034bbac4c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:03.729219 [ 3367 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:03.731184 [ 3383 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:03.746708 [ 3402 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:03.757234 [ 3894 ] {3669ece5-9801-4fa0-ac10-1f937854f77b} executeQuery: Code: 48. DB::Exception: Method write is not supported by storage SystemNumbers. (NOT_IMPLEMENTED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:54848) (comment: 02899_use_default_format_on_http_exception.sh) (in query: INSERT INTO system.numbers Select * from numbers(10); ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::IStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002ffc59e7 4. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:573: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000003ba9ef4f 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000034ba82a1 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000034bab2af 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034bb1a40 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034bbac4c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:51:03.760872 [ 3894 ] {3669ece5-9801-4fa0-ac10-1f937854f77b} DynamicQueryHandler: Code: 48. DB::Exception: Method write is not supported by storage SystemNumbers. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::IStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002ffc59e7 4. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:573: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000003ba9ef4f 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000034ba82a1 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000034bab2af 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034bb1a40 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034bbac4c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:03.800255 [ 3894 ] {3fa691c5-56a7-4414-9d34-a665a4b16cba} executeQuery: Code: 48. DB::Exception: Method write is not supported by storage SystemNumbers. (NOT_IMPLEMENTED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:54860) (comment: 02899_use_default_format_on_http_exception.sh) (in query: INSERT INTO system.numbers Select * from numbers(10); ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::IStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002ffc59e7 4. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:573: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000003ba9ef4f 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000034ba82a1 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000034bab2af 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034bb1a40 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034bbac4c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:51:03.801723 [ 3894 ] {3fa691c5-56a7-4414-9d34-a665a4b16cba} executeQuery: Code: 73. DB::Exception: Unknown format BADFORMAT. (UNKNOWN_FORMAT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Formats/FormatFactory.cpp:46: DB::FormatFactory::getCreators(String const&) const @ 0x000000003ac86bb1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:863: ? @ 0x000000003ac8fd49 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>)::$_1::operator()() const @ 0x00000000358d21c8 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358cac82 8. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 9. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:51:03.803327 [ 3894 ] {3fa691c5-56a7-4414-9d34-a665a4b16cba} DynamicQueryHandler: Code: 48. DB::Exception: Method write is not supported by storage SystemNumbers. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::IStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002ffc59e7 4. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:573: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000003ba9ef4f 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000034ba82a1 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000034bab2af 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034bb1a40 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034bbac4c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:03.876555 [ 3368 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:04.141297 [ 3364 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:04.237010 [ 3894 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x00000000315a10ad 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159da2f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b6b4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa269fb 10. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:04.577768 [ 3337 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:04.730659 [ 3341 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:04.732798 [ 3357 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:04.748669 [ 3334 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:04.877755 [ 3333 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:05.142579 [ 3372 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:05.578703 [ 3318 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:05.731913 [ 3303 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:05.733760 [ 3297 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:05.749937 [ 3306 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:05.878577 [ 3301 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:06.143517 [ 3325 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:06.229191 [ 4799 ] {646b81df-2cd6-441b-93a1-4712a7408468} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:60860) (comment: 01069_database_memory.sql) (in query: INSERT INTO memory_01069.file 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::writeSuffix() @ 0x000000003b3c762b 9. ./src/Processors/Formats/IOutputFormat.h:123: DB::IOutputFormat::finalize() @ 0x000000003af02fa5 10. ./build_docker/./src/Storages/StorageFile.cpp:1832: DB::StorageFileSink::finalizeBuffers() @ 0x0000000038376a21 11. ./build_docker/./src/Storages/StorageFile.cpp:1821: DB::StorageFileSink::onFinish() @ 0x000000003837653e 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003b82b58f 13. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b82a4b6 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b829382 15. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003aea4e44 18. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000003aef2f19 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000003abf92aa 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9316 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 27. ? @ 0x00007f100c857ac3 28. ? @ 0x00007f100c8e9850 2025.10.23 23:51:06.231265 [ 4799 ] {646b81df-2cd6-441b-93a1-4712a7408468} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::writeSuffix() @ 0x000000003b3c762b 9. ./src/Processors/Formats/IOutputFormat.h:123: DB::IOutputFormat::finalize() @ 0x000000003af02fa5 10. ./build_docker/./src/Storages/StorageFile.cpp:1832: DB::StorageFileSink::finalizeBuffers() @ 0x0000000038376a21 11. ./build_docker/./src/Storages/StorageFile.cpp:1821: DB::StorageFileSink::onFinish() @ 0x000000003837653e 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003b82b58f 13. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b82a4b6 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b829382 15. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003aea4e44 18. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000003aef2f19 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000003abf92aa 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9316 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 27. ? @ 0x00007f100c857ac3 28. ? @ 0x00007f100c8e9850 2025.10.23 23:51:06.261597 [ 3648 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {60ee07fc-67dc-4a3f-94ea-a31cb10c5a92::202510_1_191_38}: 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 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) @ 0x0000000039c89948 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000003999bfb7 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 @ 0x00000000399942f0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000039d15c04 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&) @ 0x0000000039d20399 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) @ 0x0000000039d1c606 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000396308a4 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x00000000396235dd 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000003963b3e0 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x00000000396504a0 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3c455d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:06.579569 [ 3281 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:06.732869 [ 3263 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:06.734548 [ 3255 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:06.750862 [ 3267 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:06.879464 [ 3252 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:07.088983 [ 3651 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {d60c8165-1f8c-4cd1-8084-8b8c63363ea3::202510_99_155_28}: Code: 241. DB::Exception: Memory tracker (for thread): fault injected (at specific point). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000002009b98d 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x000000002009675f 5. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:129: CurrentMemoryTracker::injectFault() @ 0x000000001ff7d1df 6. ./build_docker/./src/Common/ThreadFuzzer.cpp:270: DB::ThreadFuzzer::maybeInjectMemoryLimitException() @ 0x000000002011909f 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:151: DB::MergePlainMergeTreeTask::finish() @ 0x000000003a3c7732 8. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3c4534 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:07.144504 [ 3256 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:07.580981 [ 3231 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:07.734105 [ 3220 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:07.735313 [ 3235 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:07.845058 [ 3229 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:07.880489 [ 3218 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:08.039963 [ 4799 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:51:08.145523 [ 3217 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:08.581888 [ 3238 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:08.735228 [ 3194 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:08.736287 [ 3194 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:08.846061 [ 3172 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:08.881731 [ 3178 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:09.146749 [ 3180 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:09.582818 [ 3151 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:09.736352 [ 3133 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:09.736987 [ 3161 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:09.846962 [ 3139 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:09.882764 [ 3144 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:10.148053 [ 3142 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:10.259159 [ 4841 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:51:10.583674 [ 3115 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:10.737274 [ 3129 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:10.737729 [ 3123 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:10.848099 [ 3114 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:10.883632 [ 3112 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:11.149211 [ 3122 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:11.584474 [ 3099 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:11.753304 [ 3089 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:11.753302 [ 3083 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:11.849145 [ 3079 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:11.941857 [ 3077 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:12.150277 [ 3060 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:12.585266 [ 3296 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:12.754160 [ 3203 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:12.754211 [ 3197 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:12.850603 [ 3329 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:12.942932 [ 3562 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:13.151255 [ 3542 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:13.586097 [ 3555 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:13.754965 [ 3530 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:13.755123 [ 3546 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:13.851936 [ 3074 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:13.944060 [ 3521 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:14.190119 [ 3518 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:14.587003 [ 3509 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:14.756231 [ 3363 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:14.799171 [ 3495 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:14.852921 [ 3502 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:14.945120 [ 3494 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:15.191059 [ 3483 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:15.588318 [ 3463 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:15.757287 [ 3455 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:15.800368 [ 3459 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:15.853925 [ 3462 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:15.946285 [ 3456 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:16.254287 [ 3441 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:16.589322 [ 3426 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:16.760315 [ 3410 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:16.801262 [ 3415 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:16.855093 [ 3412 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:16.947514 [ 3411 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:17.255600 [ 3397 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:17.590284 [ 3439 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:17.761337 [ 3377 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:17.802214 [ 3367 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:17.856449 [ 3383 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:17.948708 [ 3369 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:18.256981 [ 3343 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:18.591392 [ 3334 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:18.719106 [ 30720 ] {d5a490e9-f24a-4560-bf0a-c765a12741b0} executeQuery: Code: 241. DB::Exception: Memory tracker (for query): fault injected. Would use 26.50 MiB (attempt to allocate chunk of 1573752 bytes), maximum: 9.31 GiB: while executing 'FUNCTION toString(multiply(__table1.number, 2_UInt8) : 0) -> toString(multiply(__table1.number, 2_UInt8)) String : 1'. (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:46516) (comment: 02967_parallel_replicas_join_algo_and_analyzer_2.sh) (in query: insert into num_1 select number * 2, toString(number * 2) from numbers(1e7);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, String&&, long&, String&&) @ 0x000000002009baa7 4. ./build_docker/./src/Common/MemoryTracker.cpp:284: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002009a3d3 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099272 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7ca1d 7. ./build_docker/./src/Common/Allocator.cpp:237: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001ff781e5 8. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x00000000083abdaf 9. DB::WriteBufferFromVector, 63ul, 64ul>>::nextImpl() @ 0x00000000083e931a 10. DB::WriteBuffer::write(char const*, unsigned long) @ 0x00000000083dcce5 11. void DB::detail::writeUIntTextFallback(unsigned long, DB::WriteBuffer&) @ 0x00000000084bf22a 12. 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&&) @ 0x0000000008fde8bf 13. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008fb7db0 14. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d57db 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffeaa 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 18. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a24ade 19. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b82c484 20. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acdc84 21. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae66ecb 22. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 26. ./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*) @ 0x000000003aea17d9 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 2025.10.23 23:51:18.727603 [ 30720 ] {d5a490e9-f24a-4560-bf0a-c765a12741b0} TCPHandler: Code: 241. DB::Exception: Memory tracker (for query): fault injected. Would use 26.50 MiB (attempt to allocate chunk of 1573752 bytes), maximum: 9.31 GiB: while executing 'FUNCTION toString(multiply(__table1.number, 2_UInt8) : 0) -> toString(multiply(__table1.number, 2_UInt8)) String : 1'. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, String&&, long&, String&&) @ 0x000000002009baa7 4. ./build_docker/./src/Common/MemoryTracker.cpp:284: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002009a3d3 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099272 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7ca1d 7. ./build_docker/./src/Common/Allocator.cpp:237: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001ff781e5 8. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x00000000083abdaf 9. DB::WriteBufferFromVector, 63ul, 64ul>>::nextImpl() @ 0x00000000083e931a 10. DB::WriteBuffer::write(char const*, unsigned long) @ 0x00000000083dcce5 11. void DB::detail::writeUIntTextFallback(unsigned long, DB::WriteBuffer&) @ 0x00000000084bf22a 12. 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&&) @ 0x0000000008fde8bf 13. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008fb7db0 14. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d57db 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffeaa 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 18. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a24ade 19. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b82c484 20. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020acdc84 21. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae66ecb 22. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 26. ./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*) @ 0x000000003aea17d9 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 29. ? @ 0x00007f100c857ac3 30. ? @ 0x00007f100c8e9850 2025.10.23 23:51:18.762307 [ 3316 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:18.803513 [ 3320 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:18.857638 [ 3338 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:18.949930 [ 3318 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:19.258291 [ 3313 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:19.390742 [ 7760 ] {6159ffc5-0a44-4da5-8408-6a5919b4857f} 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=9, 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202dea34 6. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:0: DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, std::shared_ptr, unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool) @ 0x0000000034775418 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr&, std::shared_ptr&, DB::SettingFieldMaxThreads const&, DB::Block const&, DB::StatsCollectingParams&, void>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::SettingFieldMaxThreads const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x0000000034df93df 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000034debf55 9. ./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&) @ 0x0000000034d95d85 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d6a797 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0b8de 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cfd8b2 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034cf6172 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5bf1 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:19.402177 [ 7760 ] {6159ffc5-0a44-4da5-8408-6a5919b4857f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=4). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:32822) (comment: 02967_parallel_replicas_join_algo_and_analyzer_2.sh) (in query: SELECT `__table1`.`key` AS `key`, `__table1`.`value` AS `value`, `__table3`.`key` AS `r.key`, `__table3`.`value` AS `r.value` FROM (SELECT `__table2`.`key` AS `key`, `__table2`.`value` AS `value` FROM `test_1`.`num_1` AS `__table2`) AS `__table1` ALL INNER JOIN (SELECT `__table4`.`key` AS `key`, `__table4`.`value` AS `value` FROM `test_1`.`num_2` AS `__table4`) AS `__table3` ON `__table1`.`key` = `__table3`.`key` ORDER BY `__table1`.`key` ASC LIMIT _CAST(700000, 'UInt64'), _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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202dea34 6. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:0: DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, std::shared_ptr, unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool) @ 0x0000000034775418 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr&, std::shared_ptr&, DB::SettingFieldMaxThreads const&, DB::Block const&, DB::StatsCollectingParams&, void>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::SettingFieldMaxThreads const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x0000000034df93df 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000034debf55 9. ./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&) @ 0x0000000034d95d85 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d6a797 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0b8de 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cfd8b2 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034cf6172 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5bf1 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 2025.10.23 23:51:19.407208 [ 7760 ] {6159ffc5-0a44-4da5-8408-6a5919b4857f} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202dea34 6. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:0: DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, std::shared_ptr, unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool) @ 0x0000000034775418 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr&, std::shared_ptr&, DB::SettingFieldMaxThreads const&, DB::Block const&, DB::StatsCollectingParams&, void>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::SettingFieldMaxThreads const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x0000000034df93df 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000034debf55 9. ./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&) @ 0x0000000034d95d85 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d6a797 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0b8de 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cfd8b2 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034cf6172 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5bf1 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 2025.10.23 23:51:19.417718 [ 30720 ] {4e24e180-583e-4c54-8110-87eacb1d54cf} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=4). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202dea34 6. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:0: DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, std::shared_ptr, unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool) @ 0x0000000034775418 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr&, std::shared_ptr&, DB::SettingFieldMaxThreads const&, DB::Block const&, DB::StatsCollectingParams&, void>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::SettingFieldMaxThreads const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x0000000034df93df 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000034debf55 9. ./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&) @ 0x0000000034d95d85 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d6a797 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0b8de 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cfd8b2 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034cf6172 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5bf1 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:46522) (comment: 02967_parallel_replicas_join_algo_and_analyzer_2.sh) (in query: select * from (select key, value from num_1) l inner join (select key, value from num_2) r on l.key = r.key order by l.key limit 10 offset 700000 SETTINGS allow_experimental_analyzer=1, allow_experimental_parallel_reading_from_replicas = 2, max_parallel_replicas = 2, parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost', parallel_replicas_prefer_local_join=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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002019af32 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000003a7e3e0c 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::Connection::receivePacket() @ 0x000000003a7ff61b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:340: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003a8df9b9 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:0: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000032358b71 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000323566d1 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032355a26 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000032352f12 2025.10.23 23:51:19.427255 [ 30720 ] {4e24e180-583e-4c54-8110-87eacb1d54cf} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=4). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202dea34 6. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:0: DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, std::shared_ptr, unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool) @ 0x0000000034775418 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr&, std::shared_ptr&, DB::SettingFieldMaxThreads const&, DB::Block const&, DB::StatsCollectingParams&, void>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::SettingFieldMaxThreads const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x0000000034df93df 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000034debf55 9. ./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&) @ 0x0000000034d95d85 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d6a797 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0b8de 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cfd8b2 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034cf6172 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5bf1 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 : 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002019af32 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000003a7e3e0c 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::Connection::receivePacket() @ 0x000000003a7ff61b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:340: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003a8df9b9 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:0: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000032358b71 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000323566d1 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032355a26 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000032352f12 2025.10.23 23:51:19.437292 [ 4799 ] {62290719-93af-4bba-aa85-eed19dea5a26} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:57816). (NETWORK_ERROR) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:57816) (comment: 02967_parallel_replicas_join_algo_and_analyzer_2.sh) (in query: SELECT `__table1`.`key` AS `key`, `__table1`.`value` AS `value`, `__table3`.`key` AS `r.key`, `__table3`.`value` AS `r.value` FROM (SELECT `__table2`.`key` AS `key`, `__table2`.`value` AS `value` FROM `test_1`.`num_1` AS `__table2`) AS `__table1` ALL INNER JOIN (SELECT `__table4`.`key` AS `key`, `__table4`.`value` AS `value` FROM `test_1`.`num_2` AS `__table4`) AS `__table3` ON `__table1`.`key` = `__table3`.`key` ORDER BY `__table1`.`key` ASC LIMIT _CAST(700000, 'UInt64'), _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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:158: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c63a0 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendEndOfStream() @ 0x000000003ac004fe 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd97c9 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:51:19.440849 [ 4799 ] {62290719-93af-4bba-aa85-eed19dea5a26} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:57816). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c6938 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000003ac2dd9a 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x000000003abff96a 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9aa8 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:19.441634 [ 4799 ] {62290719-93af-4bba-aa85-eed19dea5a26} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:57816). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:158: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c63a0 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendEndOfStream() @ 0x000000003ac004fe 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd97c9 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:51:19.445032 [ 4799 ] {62290719-93af-4bba-aa85-eed19dea5a26} TCPHandler: Client has gone away. 2025.10.23 23:51:19.592404 [ 3348 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:19.763523 [ 3356 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:19.805039 [ 3309 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:19.858884 [ 3311 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:19.950907 [ 3300 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:20.259512 [ 3287 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:20.593257 [ 3284 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:20.764897 [ 3273 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:20.806019 [ 3276 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:20.860313 [ 3266 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:20.952278 [ 3261 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:21.260928 [ 3252 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:21.594273 [ 3240 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:21.766339 [ 3247 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:21.807091 [ 3231 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:21.861533 [ 3226 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:21.953581 [ 3220 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:22.124097 [ 4799 ] {55b50995-ccd7-4b2b-982c-0274b686a0ec} DB::ConcurrentHashJoin::ConcurrentHashJoin(ContextPtr, std::shared_ptr, size_t, const Block &, const StatsCollectingParams &, bool): 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202dea34 6. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:0: DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, std::shared_ptr, unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool) @ 0x0000000034775418 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr&, std::shared_ptr&, DB::SettingFieldMaxThreads const&, DB::Block const&, DB::StatsCollectingParams&, void>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::SettingFieldMaxThreads const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x0000000034df93df 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000034debf55 9. ./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&) @ 0x0000000034d95d85 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d6a797 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0b8de 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cfd8b2 13. ./build_docker/./src/Planner/findParallelReplicasQuery.cpp:287: DB::findQueryForParallelReplicas(std::shared_ptr const&, DB::SelectQueryOptions&) @ 0x0000000034d47d75 14. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::Planner(std::shared_ptr const&, DB::SelectQueryOptions&) @ 0x0000000034cf7e4c 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:163: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceba7b 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:22.137977 [ 4799 ] {55b50995-ccd7-4b2b-982c-0274b686a0ec} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:46540) (comment: 02967_parallel_replicas_join_algo_and_analyzer_2.sh) (in query: select * from (select key, value from num_1) l inner join (select key, value from num_2) r on l.key = r.key order by l.key limit 10 offset 700000 SETTINGS allow_experimental_analyzer=1, send_logs_level='trace', allow_experimental_parallel_reading_from_replicas = 2, max_parallel_replicas = 2, parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost', parallel_replicas_prefer_local_join=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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202dea34 6. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:0: DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, std::shared_ptr, unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool) @ 0x0000000034775418 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr&, std::shared_ptr&, DB::SettingFieldMaxThreads const&, DB::Block const&, DB::StatsCollectingParams&, void>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::SettingFieldMaxThreads const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x0000000034df93df 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000034debf55 9. ./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&) @ 0x0000000034d95d85 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d6a797 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0b8de 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cfd8b2 13. ./build_docker/./src/Planner/findParallelReplicasQuery.cpp:287: DB::findQueryForParallelReplicas(std::shared_ptr const&, DB::SelectQueryOptions&) @ 0x0000000034d47d75 14. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::Planner(std::shared_ptr const&, DB::SelectQueryOptions&) @ 0x0000000034cf7e4c 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:163: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceba7b 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 2025.10.23 23:51:22.142191 [ 4799 ] {55b50995-ccd7-4b2b-982c-0274b686a0ec} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202dea34 6. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:0: DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, std::shared_ptr, unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool) @ 0x0000000034775418 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr&, std::shared_ptr&, DB::SettingFieldMaxThreads const&, DB::Block const&, DB::StatsCollectingParams&, void>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::SettingFieldMaxThreads const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x0000000034df93df 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000034debf55 9. ./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&) @ 0x0000000034d95d85 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d6a797 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0b8de 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cfd8b2 13. ./build_docker/./src/Planner/findParallelReplicasQuery.cpp:287: DB::findQueryForParallelReplicas(std::shared_ptr const&, DB::SelectQueryOptions&) @ 0x0000000034d47d75 14. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::Planner(std::shared_ptr const&, DB::SelectQueryOptions&) @ 0x0000000034cf7e4c 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:163: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceba7b 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 2025.10.23 23:51:22.261920 [ 3210 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:22.595454 [ 3202 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:22.768014 [ 3184 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:22.808642 [ 3238 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:22.862838 [ 3181 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:22.954483 [ 3183 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:23.262952 [ 3176 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:23.581556 [ 7760 ] {e2e51ce5-bbfb-48b2-b9d6-6e84db03344f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:57818) (comment: 02967_parallel_replicas_join_algo_and_analyzer_2.sh) (in query: SELECT `__table1`.`key` AS `key`, `__table1`.`value` AS `value`, `__table3`.`key` AS `r.key`, `__table3`.`value` AS `r.value` FROM (SELECT `__table2`.`key` AS `key`, `__table2`.`value` AS `value` FROM `test_1`.`num_1` AS `__table2`) AS `__table1` ALL INNER JOIN (SELECT `__table4`.`key` AS `key`, `__table4`.`value` AS `value` FROM `test_1`.`num_2` AS `__table4`) AS `__table3` ON `__table1`.`key` = `__table3`.`key` ORDER BY `__table1`.`key` ASC LIMIT _CAST(700000, 'UInt64'), _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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6377 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 2025.10.23 23:51:23.595940 [ 7760 ] {e2e51ce5-bbfb-48b2-b9d6-6e84db03344f} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6377 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 2025.10.23 23:51:23.596707 [ 3158 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:23.662565 [ 4799 ] {2aa45bb8-ccc6-48fa-b218-68991304d021} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:34720) (comment: 02967_parallel_replicas_join_algo_and_analyzer_2.sh) (in query: SELECT `__table1`.`key` AS `key`, `__table1`.`value` AS `value`, `__table3`.`key` AS `r.key`, `__table3`.`value` AS `r.value` FROM (SELECT `__table2`.`key` AS `key`, `__table2`.`value` AS `value` FROM `test_1`.`num_1` AS `__table2`) AS `__table1` ALL INNER JOIN (SELECT `__table4`.`key` AS `key`, `__table4`.`value` AS `value` FROM `test_1`.`num_2` AS `__table4`) AS `__table3` ON `__table1`.`key` = `__table3`.`key` ORDER BY `__table1`.`key` ASC LIMIT _CAST(700000, 'UInt64'), _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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6377 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 2025.10.23 23:51:23.674183 [ 4799 ] {2aa45bb8-ccc6-48fa-b218-68991304d021} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6377 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 2025.10.23 23:51:23.686996 [ 4841 ] {7b134f30-0fde-4be3-b9a8-e2a16fddc805} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.3:9000. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=7). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6377 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:46596) (comment: 02967_parallel_replicas_join_algo_and_analyzer_2.sh) (in query: select * from (select key, value from num_1) l inner join (select key, value from num_2) r on l.key = r.key order by l.key limit 10 offset 700000 SETTINGS allow_experimental_analyzer=1, join_algorithm='full_sorting_merge', send_logs_level='trace', allow_experimental_parallel_reading_from_replicas = 2, max_parallel_replicas = 2, parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost', parallel_replicas_prefer_local_join=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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002019af32 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000003a7e3e0c 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::Connection::receivePacket() @ 0x000000003a7ff61b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:340: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003a8df9b9 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:0: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000032358b71 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000323566d1 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032355a26 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000032352f12 2025.10.23 23:51:23.692753 [ 4799 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:34720, 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x00000000204bfd30 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x00000000204c0cc1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a8112cd 6. DB::ReadBuffer::next() @ 0x00000000095b468f 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000003abd729e 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:23.696597 [ 4841 ] {7b134f30-0fde-4be3-b9a8-e2a16fddc805} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.3:9000. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=7). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6377 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003aea8978 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 : 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002019af32 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000003a7e3e0c 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::Connection::receivePacket() @ 0x000000003a7ff61b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:340: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003a8df9b9 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:0: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000032358b71 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000323566d1 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032355a26 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000032352f12 2025.10.23 23:51:23.769310 [ 3150 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:23.809750 [ 3152 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:23.864572 [ 3147 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:23.955647 [ 3154 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:24.177261 [ 4674 ] {6b5836cc-cb34-46ab-845d-3dfaafd682cf} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:48166) (comment: 00844_join_lightee2.sql) (in query: SELECT `__table1`.`f1` AS `f1`, `__table2`.`f3` AS `f3` FROM `test_15`.`t1_00844` AS `__table1` ALL INNER JOIN `test_15`.`t2_00844` AS `__table2` ON `__table1`.`f2` = `__table2`.`f1` WHERE `__table2`.`f1` = '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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:51:24.185211 [ 4674 ] {6b5836cc-cb34-46ab-845d-3dfaafd682cf} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:51:24.218409 [ 32132 ] {0a6e65c8-5d94-48be-8605-50769199e35b} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.3:9000. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:46588) (comment: 00844_join_lightee2.sql) (in query: select t1_00844.f1,t2_00844.f3 from t1_00844 all inner join t2_00844 on t1_00844.f2 = t2_00844.f1 where t2_00844.f1 = '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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002019af32 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000003a7e3e0c 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::Connection::receivePacket() @ 0x000000003a7ff61b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:340: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003a8df9b9 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:0: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000032358b71 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000323566d1 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032355a26 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000032352f12 2025.10.23 23:51:24.264180 [ 3125 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:24.298078 [ 32132 ] {0a6e65c8-5d94-48be-8605-50769199e35b} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.3:9000. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 : 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002019af32 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000003a7e3e0c 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::Connection::receivePacket() @ 0x000000003a7ff61b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:340: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003a8df9b9 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:0: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000032358b71 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000323566d1 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032355a26 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000032352f12 2025.10.23 23:51:24.597880 [ 3136 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:24.770701 [ 3140 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:24.811000 [ 3114 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:24.865738 [ 3130 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:24.966571 [ 3113 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:25.265877 [ 3132 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:25.428720 [ 9453 ] {f4589237-1d8f-4a41-bded-016fff549716} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:34398). (NETWORK_ERROR) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:34398) (comment: 00844_join_lightee2.sql) (in query: SELECT `__table1`.`f1` AS `f1`, `__table2`.`f3` AS `f3` FROM `test_15`.`t1_00844` AS `__table1` ALL INNER JOIN `test_15`.`t2_00844` AS `__table2` ON `__table1`.`f2` = `__table2`.`f1` WHERE `__table2`.`f1` = '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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:158: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c63a0 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000003ac044bd 6. ./src/Core/Block.h:37: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfc281 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 2025.10.23 23:51:25.434735 [ 9453 ] {f4589237-1d8f-4a41-bded-016fff549716} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:34398). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c6938 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000003ac2dd9a 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x000000003abff96a 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9aa8 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:25.435149 [ 9453 ] {f4589237-1d8f-4a41-bded-016fff549716} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:34398). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:158: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c63a0 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000003ac044bd 6. ./src/Core/Block.h:37: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfc281 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 2025.10.23 23:51:25.435970 [ 9453 ] {f4589237-1d8f-4a41-bded-016fff549716} TCPHandler: Client has gone away. 2025.10.23 23:51:25.598859 [ 3100 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:25.772056 [ 3082 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:25.812649 [ 3088 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:25.867003 [ 3087 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:25.968015 [ 3075 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:25.999400 [ 4841 ] {2bec1417-dad9-49ae-a4dd-9430934a3cdf} DB::ConcurrentHashJoin::ConcurrentHashJoin(ContextPtr, std::shared_ptr, size_t, const Block &, const StatsCollectingParams &, bool): 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202dea34 6. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:0: DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, std::shared_ptr, unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool) @ 0x0000000034775418 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr&, std::shared_ptr&, DB::SettingFieldMaxThreads const&, DB::Block const&, DB::StatsCollectingParams&, void>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::SettingFieldMaxThreads const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x0000000034df93df 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000034debf55 9. ./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&) @ 0x0000000034d95d85 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d6a797 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0b8de 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cfd8b2 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034cf6172 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5bf1 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:26.013070 [ 4841 ] {2bec1417-dad9-49ae-a4dd-9430934a3cdf} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:46608) (comment: 02967_parallel_replicas_join_algo_and_analyzer_2.sh) (in query: select * from (select key, value from num_1) l inner join (select key, value from num_2 inner join (select number * 7 as key from numbers(1e5)) as nn on num_2.key = nn.key settings parallel_replicas_prefer_local_join=1) r on l.key = r.key order by l.key limit 10 offset 10000 SETTINGS allow_experimental_analyzer=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202dea34 6. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:0: DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, std::shared_ptr, unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool) @ 0x0000000034775418 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr&, std::shared_ptr&, DB::SettingFieldMaxThreads const&, DB::Block const&, DB::StatsCollectingParams&, void>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::SettingFieldMaxThreads const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x0000000034df93df 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000034debf55 9. ./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&) @ 0x0000000034d95d85 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d6a797 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0b8de 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cfd8b2 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034cf6172 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5bf1 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 2025.10.23 23:51:26.016466 [ 4841 ] {2bec1417-dad9-49ae-a4dd-9430934a3cdf} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202dea34 6. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:0: DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, std::shared_ptr, unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool) @ 0x0000000034775418 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr&, std::shared_ptr&, DB::SettingFieldMaxThreads const&, DB::Block const&, DB::StatsCollectingParams&, void>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::SettingFieldMaxThreads const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x0000000034df93df 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000034debf55 9. ./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&) @ 0x0000000034d95d85 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d6a797 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0b8de 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cfd8b2 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034cf6172 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5bf1 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 2025.10.23 23:51:26.267373 [ 3070 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:26.600089 [ 3104 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:26.773122 [ 3073 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:26.813970 [ 3067 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:26.868298 [ 3396 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:26.969097 [ 3345 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:27.268687 [ 3265 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:27.601292 [ 3071 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:27.774400 [ 3141 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:27.815252 [ 3098 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:27.869432 [ 3564 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:27.970218 [ 3551 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:28.236914 [ 4841 ] {b4ef525c-fdbd-4b73-9905-0d1cc941c133} DB::ConcurrentHashJoin::ConcurrentHashJoin(ContextPtr, std::shared_ptr, size_t, const Block &, const StatsCollectingParams &, bool): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202dea34 6. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:0: DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, std::shared_ptr, unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool) @ 0x0000000034775418 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr&, std::shared_ptr&, DB::SettingFieldMaxThreads const&, DB::Block const&, DB::StatsCollectingParams&, void>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::SettingFieldMaxThreads const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x0000000034df93df 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000034debf55 9. ./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&) @ 0x0000000034d95d85 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d6a797 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0b8de 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cfd8b2 13. ./build_docker/./src/Planner/findParallelReplicasQuery.cpp:287: DB::findQueryForParallelReplicas(std::shared_ptr const&, DB::SelectQueryOptions&) @ 0x0000000034d47d75 14. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::Planner(std::shared_ptr const&, DB::SelectQueryOptions&) @ 0x0000000034cf7e4c 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:163: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceba7b 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:28.269953 [ 3534 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:28.602411 [ 3532 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:28.776463 [ 3537 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:28.816550 [ 3074 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:28.870622 [ 3523 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:28.971412 [ 3511 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:29.271633 [ 3506 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:29.603415 [ 3469 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:29.777748 [ 3471 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:29.817490 [ 3463 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:29.871655 [ 3461 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:29.929424 [ 3656 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {c84fffe3-f7b9-426e-917b-60cee886efa2::202510_1_187_38}: 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 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) @ 0x0000000039c89948 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000003999bfb7 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 @ 0x00000000399942f0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000039d15c04 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&) @ 0x0000000039d20399 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) @ 0x0000000039d1c606 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000396308a4 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x00000000396235dd 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000003963b3e0 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x00000000396504a0 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3c455d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:29.972347 [ 3459 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:30.125558 [ 4841 ] {b4ef525c-fdbd-4b73-9905-0d1cc941c133} virtual DB::ConcurrentHashJoin::~ConcurrentHashJoin(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202dea34 6. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:0: DB::ConcurrentHashJoin::~ConcurrentHashJoin() @ 0x0000000034776701 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:313: std::__shared_ptr_emplace>::__on_zero_shared() @ 0x0000000033adba20 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:216: DB::JoinStep::~JoinStep() @ 0x000000003be79c70 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:119: std::__list_imp>::clear() @ 0x000000003bee2e7f 10. ./contrib/llvm-project/libcxx/include/list:575: DB::QueryPlan::~QueryPlan() @ 0x000000003beb1a84 11. ./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&) @ 0x0000000034d9ef4b 12. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d6a797 13. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0b8de 14. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cfd8b2 15. ./build_docker/./src/Planner/findParallelReplicasQuery.cpp:287: DB::findQueryForParallelReplicas(std::shared_ptr const&, DB::SelectQueryOptions&) @ 0x0000000034d47d75 16. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::Planner(std::shared_ptr const&, DB::SelectQueryOptions&) @ 0x0000000034cf7e4c 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:163: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceba7b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 30. ? @ 0x00007f100c857ac3 31. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:30.134112 [ 4841 ] {b4ef525c-fdbd-4b73-9905-0d1cc941c133} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:40802) (comment: 02967_parallel_replicas_join_algo_and_analyzer_2.sh) (in query: select * from (select key, value from num_1) l inner join (select key, value from num_2 inner join (select number * 7 as key from numbers(1e5)) as nn on num_2.key = nn.key settings parallel_replicas_prefer_local_join=1) r on l.key = r.key order by l.key limit 10 offset 10000 SETTINGS allow_experimental_analyzer=1, allow_experimental_parallel_reading_from_replicas = 2, max_parallel_replicas = 2, parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost', parallel_replicas_prefer_local_join=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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202dea34 6. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:0: DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, std::shared_ptr, unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool) @ 0x0000000034775418 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr&, std::shared_ptr&, DB::SettingFieldMaxThreads const&, DB::Block const&, DB::StatsCollectingParams&, void>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::SettingFieldMaxThreads const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x0000000034df93df 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000034debf55 9. ./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&) @ 0x0000000034d95d85 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d6a797 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0b8de 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cfd8b2 13. ./build_docker/./src/Planner/findParallelReplicasQuery.cpp:287: DB::findQueryForParallelReplicas(std::shared_ptr const&, DB::SelectQueryOptions&) @ 0x0000000034d47d75 14. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::Planner(std::shared_ptr const&, DB::SelectQueryOptions&) @ 0x0000000034cf7e4c 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:163: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceba7b 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 2025.10.23 23:51:30.137346 [ 4841 ] {b4ef525c-fdbd-4b73-9905-0d1cc941c133} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202dea34 6. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:0: DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, std::shared_ptr, unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool) @ 0x0000000034775418 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr&, std::shared_ptr&, DB::SettingFieldMaxThreads const&, DB::Block const&, DB::StatsCollectingParams&, void>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::SettingFieldMaxThreads const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x0000000034df93df 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000034debf55 9. ./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&) @ 0x0000000034d95d85 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d6a797 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0b8de 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cfd8b2 13. ./build_docker/./src/Planner/findParallelReplicasQuery.cpp:287: DB::findQueryForParallelReplicas(std::shared_ptr const&, DB::SelectQueryOptions&) @ 0x0000000034d47d75 14. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::Planner(std::shared_ptr const&, DB::SelectQueryOptions&) @ 0x0000000034cf7e4c 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:163: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceba7b 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 2025.10.23 23:51:30.272941 [ 3449 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:30.604213 [ 3445 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:30.778918 [ 3436 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:30.818211 [ 3420 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:30.872624 [ 3417 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:30.959138 [ 7760 ] {491d4a4b-96fe-47e4-a5e5-16cce5d77d95} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=10, jobs=10). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:47626) (comment: 02967_parallel_replicas_join_algo_and_analyzer_2.sh) (in query: SELECT `__table1`.`key` AS `key`, `__table1`.`value` AS `value`, `__table3`.`key` AS `r.key`, `__table3`.`value` AS `r.value` FROM (SELECT `__table2`.`key` AS `key`, `__table2`.`value` AS `value` FROM `test_1`.`num_1` AS `__table2`) AS `__table1` ALL INNER JOIN (SELECT `__table4`.`key` AS `key`, `__table4`.`value` AS `value` FROM `test_1`.`num_2` AS `__table4` ALL INNER JOIN (SELECT `__table6`.`number` * 7 AS `key` FROM numbers(100000.) AS `__table6`) AS `__table5` ON `__table4`.`key` = `__table5`.`key` SETTINGS parallel_replicas_prefer_local_join = 1) AS `__table3` ON `__table1`.`key` = `__table3`.`key` ORDER BY `__table1`.`key` ASC LIMIT _CAST(10000, 'UInt64'), _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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:51:30.973340 [ 3415 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:30.976604 [ 7760 ] {491d4a4b-96fe-47e4-a5e5-16cce5d77d95} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:51:31.097656 [ 4841 ] {78587a32-d7fa-42bb-bf16-7d0d9057558c} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Cannot schedule a task: failed to start the thread (threads=10, jobs=10). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:40850) (comment: 02967_parallel_replicas_join_algo_and_analyzer_2.sh) (in query: select * from (select key, value from num_1) l inner join (select key, value from num_2 inner join (select number * 7 as key from numbers(1e5)) as nn on num_2.key = nn.key settings parallel_replicas_prefer_local_join=1) r on l.key = r.key order by l.key limit 10 offset 10000 SETTINGS allow_experimental_analyzer=1, join_algorithm='full_sorting_merge', send_logs_level='trace', allow_experimental_parallel_reading_from_replicas = 2, max_parallel_replicas = 2, parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost', parallel_replicas_prefer_local_join=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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002019af32 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000003a7e3e0c 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::Connection::receivePacket() @ 0x000000003a7ff61b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:340: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003a8df9b9 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:0: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000032358b71 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000323566d1 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032355a26 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000032352f12 2025.10.23 23:51:31.103348 [ 4841 ] {78587a32-d7fa-42bb-bf16-7d0d9057558c} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Cannot schedule a task: failed to start the thread (threads=10, jobs=10). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 : 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002019af32 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000003a7e3e0c 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::Connection::receivePacket() @ 0x000000003a7ff61b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:340: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003a8df9b9 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:0: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000032358b71 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000323566d1 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032355a26 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000032352f12 2025.10.23 23:51:31.119193 [ 9453 ] {586cc23a-d164-4194-8507-d247a69e6c0e} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:45546). (NETWORK_ERROR) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:45546) (comment: 02967_parallel_replicas_join_algo_and_analyzer_2.sh) (in query: SELECT `__table1`.`key` AS `key`, `__table1`.`value` AS `value`, `__table3`.`key` AS `r.key`, `__table3`.`value` AS `r.value` FROM (SELECT `__table2`.`key` AS `key`, `__table2`.`value` AS `value` FROM `test_1`.`num_1` AS `__table2`) AS `__table1` ALL INNER JOIN (SELECT `__table4`.`key` AS `key`, `__table4`.`value` AS `value` FROM `test_1`.`num_2` AS `__table4` ALL INNER JOIN (SELECT `__table6`.`number` * 7 AS `key` FROM numbers(100000.) AS `__table6`) AS `__table5` ON `__table4`.`key` = `__table5`.`key` SETTINGS parallel_replicas_prefer_local_join = 1) AS `__table3` ON `__table1`.`key` = `__table3`.`key` ORDER BY `__table1`.`key` ASC LIMIT _CAST(10000, 'UInt64'), _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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c6938 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileInfo(DB::ProfileInfo const&) @ 0x000000003ac0e495 6. ./build_docker/./src/Server/TCPHandler.cpp:1165: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfc070 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 2025.10.23 23:51:31.237842 [ 9453 ] {586cc23a-d164-4194-8507-d247a69e6c0e} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:45546). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c6938 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000003ac2dd9a 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x000000003abff96a 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9aa8 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:31.238500 [ 9453 ] {586cc23a-d164-4194-8507-d247a69e6c0e} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:45546). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c6938 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileInfo(DB::ProfileInfo const&) @ 0x000000003ac0e495 6. ./build_docker/./src/Server/TCPHandler.cpp:1165: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfc070 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 2025.10.23 23:51:31.239524 [ 9453 ] {586cc23a-d164-4194-8507-d247a69e6c0e} TCPHandler: Client has gone away. 2025.10.23 23:51:31.273765 [ 3408 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:31.605041 [ 3390 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:31.780224 [ 3388 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:31.819162 [ 3380 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:31.873686 [ 3377 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:31.974628 [ 3376 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:32.274664 [ 3364 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:32.606107 [ 3349 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:32.781491 [ 3365 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:32.820553 [ 3347 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:32.874846 [ 3357 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:32.975809 [ 3328 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:33.275971 [ 3304 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:33.607260 [ 3327 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:33.783137 [ 3348 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:33.795075 [ 4799 ] {e57f812b-9c02-4f95-bfe6-2295336a3b8c} executeQuery: Code: 999. Coordination::Exception: Fault injection before operation. (KEEPER_EXCEPTION) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:40834) (comment: 02456_keeper_retries_during_insert.sql) (in query: INSERT INTO keeper_retries_r1 SETTINGS insert_keeper_fault_injection_probability=1, insert_keeper_max_retries=0 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRKPKcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS7_11char_traitsIcEENS7_9allocatorIcEEEEEEEOS6_NS_5ErrorE @ 0x000000003cd71ca7 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRKPKcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS7_11char_traitsIcEENS7_9allocatorIcEEEEEEES0_NS_5ErrorEOS6_ @ 0x000000003cd6b544 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:107: DB::ZooKeeperWithFaultInjection::injectFailureBeforeOperationThrow(char const*, String const&) @ 0x000000003cd5ae9b 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:0: DB::ZooKeeperWithFaultInjection::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003cd5f3c6 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6727: DB::StorageReplicatedMergeTree::existsNodeCached(std::shared_ptr const&, String const&) const @ 0x00000000386e8802 7. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6764: std::optional DB::StorageReplicatedMergeTree::allocateBlockNumber(String const&, std::shared_ptr const&, String const&, String const&) const @ 0x0000000038abedea 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000003a240a09 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000003a23f9db 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()::operator()() const @ 0x000000003a23f659 11. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000003a23f05f 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1133: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x000000003a209ab0 13. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:463: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x000000003a1dcdb4 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeSinkImpl::onFinish() @ 0x000000003a207778 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003b82b58f 16. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b82a4b6 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b829382 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003aea4e44 21. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000003aef2f19 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000003abf92aa 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9316 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 30. ? @ 0x00007f100c857ac3 31. ? @ 0x00007f100c8e9850 2025.10.23 23:51:33.800487 [ 4799 ] {e57f812b-9c02-4f95-bfe6-2295336a3b8c} TCPHandler: Code: 999. Coordination::Exception: Fault injection before operation. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRKPKcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS7_11char_traitsIcEENS7_9allocatorIcEEEEEEEOS6_NS_5ErrorE @ 0x000000003cd71ca7 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRKPKcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS7_11char_traitsIcEENS7_9allocatorIcEEEEEEES0_NS_5ErrorEOS6_ @ 0x000000003cd6b544 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:107: DB::ZooKeeperWithFaultInjection::injectFailureBeforeOperationThrow(char const*, String const&) @ 0x000000003cd5ae9b 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:0: DB::ZooKeeperWithFaultInjection::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003cd5f3c6 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6727: DB::StorageReplicatedMergeTree::existsNodeCached(std::shared_ptr const&, String const&) const @ 0x00000000386e8802 7. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6764: std::optional DB::StorageReplicatedMergeTree::allocateBlockNumber(String const&, std::shared_ptr const&, String const&, String const&) const @ 0x0000000038abedea 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000003a240a09 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000003a23f9db 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()::operator()() const @ 0x000000003a23f659 11. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000003a23f05f 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1133: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x000000003a209ab0 13. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:463: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x000000003a1dcdb4 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeSinkImpl::onFinish() @ 0x000000003a207778 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003b82b58f 16. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b82a4b6 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b829382 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003aea4e44 21. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000003aef2f19 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000003abf92aa 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9316 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 30. ? @ 0x00007f100c857ac3 31. ? @ 0x00007f100c8e9850 2025.10.23 23:51:33.821804 [ 3298 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:33.876389 [ 3331 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:33.976850 [ 3356 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:34.277037 [ 3300 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:34.608532 [ 3292 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:34.784336 [ 3283 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:34.822842 [ 3277 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:34.877558 [ 3281 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:34.977799 [ 3276 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:35.004903 [ 4799 ] {31f9b85f-d806-43d6-b942-ad8ddf433d39} executeQuery: Code: 999. Coordination::Exception: Fault injection before operation. (KEEPER_EXCEPTION) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:40834) (comment: 02456_keeper_retries_during_insert.sql) (in query: INSERT INTO keeper_retries_r1 SETTINGS insert_keeper_fault_injection_probability=1, insert_keeper_retry_max_backoff_ms=10 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRKPKcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS7_11char_traitsIcEENS7_9allocatorIcEEEEEEEOS6_NS_5ErrorE @ 0x000000003cd71ca7 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRKPKcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS7_11char_traitsIcEENS7_9allocatorIcEEEEEEES0_NS_5ErrorEOS6_ @ 0x000000003cd6b544 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:107: DB::ZooKeeperWithFaultInjection::injectFailureBeforeOperationThrow(char const*, String const&) @ 0x000000003cd5ae9b 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:0: DB::ZooKeeperWithFaultInjection::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003cd5f3c6 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6727: DB::StorageReplicatedMergeTree::existsNodeCached(std::shared_ptr const&, String const&) const @ 0x00000000386e8802 7. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6764: std::optional DB::StorageReplicatedMergeTree::allocateBlockNumber(String const&, std::shared_ptr const&, String const&, String const&) const @ 0x0000000038abedea 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000003a240a09 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000003a23f9db 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()::operator()() const @ 0x000000003a23f659 11. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000003a23f05f 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1133: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x000000003a209ab0 13. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:463: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x000000003a1dcdb4 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeSinkImpl::onFinish() @ 0x000000003a207778 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003b82b58f 16. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b82a4b6 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b829382 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003aea4e44 21. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000003aef2f19 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000003abf92aa 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9316 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 30. ? @ 0x00007f100c857ac3 31. ? @ 0x00007f100c8e9850 2025.10.23 23:51:35.010565 [ 4799 ] {31f9b85f-d806-43d6-b942-ad8ddf433d39} TCPHandler: Code: 999. Coordination::Exception: Fault injection before operation. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRKPKcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS7_11char_traitsIcEENS7_9allocatorIcEEEEEEEOS6_NS_5ErrorE @ 0x000000003cd71ca7 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRKPKcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS7_11char_traitsIcEENS7_9allocatorIcEEEEEEES0_NS_5ErrorEOS6_ @ 0x000000003cd6b544 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:107: DB::ZooKeeperWithFaultInjection::injectFailureBeforeOperationThrow(char const*, String const&) @ 0x000000003cd5ae9b 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:0: DB::ZooKeeperWithFaultInjection::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003cd5f3c6 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6727: DB::StorageReplicatedMergeTree::existsNodeCached(std::shared_ptr const&, String const&) const @ 0x00000000386e8802 7. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6764: std::optional DB::StorageReplicatedMergeTree::allocateBlockNumber(String const&, std::shared_ptr const&, String const&, String const&) const @ 0x0000000038abedea 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000003a240a09 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000003a23f9db 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()::operator()() const @ 0x000000003a23f659 11. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000003a23f05f 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1133: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x000000003a209ab0 13. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:463: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x000000003a1dcdb4 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeSinkImpl::onFinish() @ 0x000000003a207778 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003b82b58f 16. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b82a4b6 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b829382 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003aea4e44 21. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000003aef2f19 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000003abf92aa 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9316 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 30. ? @ 0x00007f100c857ac3 31. ? @ 0x00007f100c8e9850 2025.10.23 23:51:35.278111 [ 3250 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:35.609570 [ 3259 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:35.785537 [ 3242 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:35.824111 [ 3240 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:35.878483 [ 3227 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:35.978645 [ 3226 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:36.279341 [ 3237 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:36.610608 [ 3225 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:36.786702 [ 3196 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:36.825075 [ 3209 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:36.879953 [ 3208 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:36.979472 [ 3193 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:37.280863 [ 3194 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:37.611549 [ 3166 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:37.787843 [ 3160 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:37.825914 [ 3169 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:37.833952 [ 4799 ] {5bff96c7-5134-42a6-814a-df94fe82760a} executeQuery: Code: 999. Coordination::Exception: Fault injection before operation. (KEEPER_EXCEPTION) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:40834) (comment: 02456_keeper_retries_during_insert.sql) (in query: INSERT INTO keeper_retries_r1 SETTINGS insert_keeper_fault_injection_probability=1, insert_keeper_max_retries=0 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRKPKcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS7_11char_traitsIcEENS7_9allocatorIcEEEEEEEOS6_NS_5ErrorE @ 0x000000003cd71ca7 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRKPKcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS7_11char_traitsIcEENS7_9allocatorIcEEEEEEES0_NS_5ErrorEOS6_ @ 0x000000003cd6b544 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:107: DB::ZooKeeperWithFaultInjection::injectFailureBeforeOperationThrow(char const*, String const&) @ 0x000000003cd5ae9b 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ZooKeeperWithFaultInjection::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000003cd5cdcb 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a239fc9 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a238ebf 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:267: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a206c3e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a1ff49f 10. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bb51384 11. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b82a9a9 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b82a4b6 13. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b829167 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003aea4e44 17. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000003aef2f19 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000003abf92aa 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9316 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 26. ? @ 0x00007f100c857ac3 27. ? @ 0x00007f100c8e9850 2025.10.23 23:51:37.835626 [ 4799 ] {5bff96c7-5134-42a6-814a-df94fe82760a} TCPHandler: Code: 999. Coordination::Exception: Fault injection before operation. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRKPKcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS7_11char_traitsIcEENS7_9allocatorIcEEEEEEEOS6_NS_5ErrorE @ 0x000000003cd71ca7 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRKPKcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS7_11char_traitsIcEENS7_9allocatorIcEEEEEEES0_NS_5ErrorEOS6_ @ 0x000000003cd6b544 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:107: DB::ZooKeeperWithFaultInjection::injectFailureBeforeOperationThrow(char const*, String const&) @ 0x000000003cd5ae9b 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ZooKeeperWithFaultInjection::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000003cd5cdcb 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a239fc9 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a238ebf 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:267: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a206c3e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a1ff49f 10. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bb51384 11. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b82a9a9 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b82a4b6 13. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b829167 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003aea4e44 17. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000003aef2f19 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000003abf92aa 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9316 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 26. ? @ 0x00007f100c857ac3 27. ? @ 0x00007f100c8e9850 2025.10.23 23:51:37.881558 [ 3151 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:37.980500 [ 3150 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:38.030572 [ 4799 ] {136e72fe-5a2c-4ef1-a0b3-565fa9bd7a8a} executeQuery: Code: 999. Coordination::Exception: Fault injection before operation. (KEEPER_EXCEPTION) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:40834) (comment: 02456_keeper_retries_during_insert.sql) (in query: INSERT INTO keeper_retries_r1 SETTINGS insert_keeper_fault_injection_probability=1, insert_keeper_retry_max_backoff_ms=1 VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRKPKcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS7_11char_traitsIcEENS7_9allocatorIcEEEEEEEOS6_NS_5ErrorE @ 0x000000003cd71ca7 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRKPKcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS7_11char_traitsIcEENS7_9allocatorIcEEEEEEES0_NS_5ErrorEOS6_ @ 0x000000003cd6b544 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:107: DB::ZooKeeperWithFaultInjection::injectFailureBeforeOperationThrow(char const*, String const&) @ 0x000000003cd5ae9b 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ZooKeeperWithFaultInjection::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000003cd5cdcb 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a239fc9 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a238ebf 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:267: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a206c3e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a1ff49f 10. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bb51384 11. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b82a9a9 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b82a4b6 13. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b829167 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003aea4e44 17. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000003aef2f19 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000003abf92aa 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9316 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 26. ? @ 0x00007f100c857ac3 27. ? @ 0x00007f100c8e9850 2025.10.23 23:51:38.032826 [ 4799 ] {136e72fe-5a2c-4ef1-a0b3-565fa9bd7a8a} TCPHandler: Code: 999. Coordination::Exception: Fault injection before operation. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. ./src/Common/Exception.h:0: _ZN12Coordination9ExceptionC2IRKPKcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS7_11char_traitsIcEENS7_9allocatorIcEEEEEEEOS6_NS_5ErrorE @ 0x000000003cd71ca7 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRKPKcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS7_11char_traitsIcEENS7_9allocatorIcEEEEEEES0_NS_5ErrorEOS6_ @ 0x000000003cd6b544 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:107: DB::ZooKeeperWithFaultInjection::injectFailureBeforeOperationThrow(char const*, String const&) @ 0x000000003cd5ae9b 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ZooKeeperWithFaultInjection::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000003cd5cdcb 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a239fc9 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a238ebf 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:267: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a206c3e 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a1ff49f 10. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bb51384 11. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b82a9a9 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b82a4b6 13. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b829167 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003aea4e44 17. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000003aef2f19 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000003abf92aa 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9316 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 26. ? @ 0x00007f100c857ac3 27. ? @ 0x00007f100c8e9850 2025.10.23 23:51:38.208120 [ 4799 ] {439a52a7-1fda-40b1-81c6-e54a5640b527} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:40834) (comment: 02456_keeper_retries_during_insert.sql) (in query: -- INSERT INTO keeper_retries_r1 SETTINGS insert_keeper_fault_injection_mode=1, insert_keeper_fault_injection_probability=0.05, insert_keeper_fault_injection_seed=1 VALUES (21); -- INSERT INTO keeper_retries_r1 SETTINGS insert_keeper_fault_injection_mode=1, insert_keeper_fault_injection_probability=0.2, insert_keeper_max_retries=100, insert_keeper_retry_max_backoff_ms=1, insert_keeper_fault_injection_seed=2 VALUES (22); -- INSERT INTO keeper_retries_r1 SETTINGS insert_keeper_fault_injection_mode=1, insert_keeper_fault_injection_probability=0.3, insert_keeper_max_retries=100, insert_keeper_retry_max_backoff_ms=1, insert_keeper_fault_injection_seed=3 VALUES (23); -- INSERT INTO keeper_retries_r1 SETTINGS insert_keeper_fault_injection_mode=1, insert_keeper_fault_injection_probability=0.4, insert_keeper_max_retries=100, insert_keeper_retry_max_backoff_ms=1, insert_keeper_fault_injection_seed=4 VALUES (24); SELECT * FROM keeper_retries_r1 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:51:38.214958 [ 4799 ] {439a52a7-1fda-40b1-81c6-e54a5640b527} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:51:38.282163 [ 3121 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:38.612730 [ 3123 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:38.789249 [ 3131 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:38.827101 [ 3127 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:38.882817 [ 3112 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:38.981704 [ 3113 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:39.283518 [ 3097 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:39.399546 [ 7760 ] {738d2fdb-d93b-4759-9758-4b076e74cb17} executeQuery: Code: 117. DB::Exception: Incorrect arguments h3Index: 72057594037927935, k: 10, error: 2: In scope SELECT h3HexRing(72057594037927935, toUInt16(10)). (INCORRECT_DATA) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:40890) (comment: 01659_h3_buffer_overflow.sql) (in query: SELECT h3HexRing(0xFFFFFFFFFFFFFF, toUInt16(10)) FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, int const&, unsigned int&) @ 0x0000000012372637 4. DB::(anonymous namespace)::FunctionH3HexRing::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012370ec0 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 2025.10.23 23:51:39.401413 [ 7760 ] {738d2fdb-d93b-4759-9758-4b076e74cb17} TCPHandler: Code: 117. DB::Exception: Incorrect arguments h3Index: 72057594037927935, k: 10, error: 2: In scope SELECT h3HexRing(72057594037927935, toUInt16(10)). (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, int const&, unsigned int&) @ 0x0000000012372637 4. DB::(anonymous namespace)::FunctionH3HexRing::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012370ec0 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 2025.10.23 23:51:39.426204 [ 7760 ] {9722de98-88f0-4b90-90de-11b3409c2be2} executeQuery: Code: 117. DB::Exception: Incorrect arguments h3Index: 72057594037927935, k: 10000, error: 2: In scope SELECT h3HexRing(72057594037927935, toUInt16(10000)). (INCORRECT_DATA) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:40890) (comment: 01659_h3_buffer_overflow.sql) (in query: SELECT h3HexRing(0xFFFFFFFFFFFFFF, toUInt16(10000)) FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, int const&, unsigned int&) @ 0x0000000012372637 4. DB::(anonymous namespace)::FunctionH3HexRing::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012370ec0 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 2025.10.23 23:51:39.427624 [ 7760 ] {9722de98-88f0-4b90-90de-11b3409c2be2} TCPHandler: Code: 117. DB::Exception: Incorrect arguments h3Index: 72057594037927935, k: 10000, error: 2: In scope SELECT h3HexRing(72057594037927935, toUInt16(10000)). (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, int const&, unsigned int&) @ 0x0000000012372637 4. DB::(anonymous namespace)::FunctionH3HexRing::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012370ec0 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fe9f0 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffb8f 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 2025.10.23 23:51:39.613753 [ 3083 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:39.790712 [ 3075 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:39.828347 [ 3090 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:39.897712 [ 3085 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:39.983146 [ 3105 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:40.285128 [ 3077 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:40.615182 [ 3060 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:40.797220 [ 3427 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:40.829504 [ 3054 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:40.876921 [ 4674 ] {2385a0d5-200e-48ab-ab18-2ce808b69d17} executeQuery: Code: 36. DB::Exception: Incorrect type of ID column: must be UInt64, but it is String. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59226) (comment: 03198_dictionary_validate_primary_key_type.sql) (in query: CREATE DICTIONARY `test_dictionary1` ( `n1` String, `n2` UInt32 ) PRIMARY KEY n1 SOURCE(CLICKHOUSE(HOST 'localhost' PORT 9000 DB 'test_db' TABLE 'table_01' USER 'default')) LIFETIME(MIN 1 MAX 10) 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000001409b14a 4. ./build_docker/./src/Storages/StorageDictionary.cpp:61: DB::StorageDictionary::getNamesAndTypes(DB::DictionaryStructure const&, bool) @ 0x0000000038254d9f 5. ./build_docker/./src/Storages/StorageDictionary.cpp:0: DB::StorageDictionary::StorageDictionary(DB::StorageID const&, String const&, DB::DictionaryStructure const&, String const&, DB::StorageDictionary::Location, std::shared_ptr) @ 0x0000000038255de5 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageDictionary::StorageDictionary(DB::StorageID const&, Poco::AutoPtr, std::shared_ptr) @ 0x0000000038256789 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15007]&, std::shared_ptr&>(std::allocator, DB::StorageID&, Poco::AutoPtr&, std::shared_ptr&) @ 0x0000000038263e0a 8. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID&, Poco::AutoPtr&, std::shared_ptr&, void>(std::allocator const&, DB::StorageID&, Poco::AutoPtr&, std::shared_ptr&) @ 0x0000000038263b03 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000003825f560 10. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x0000000038308626 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348e414c 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 2025.10.23 23:51:40.878984 [ 4674 ] {2385a0d5-200e-48ab-ab18-2ce808b69d17} TCPHandler: Code: 36. DB::Exception: Incorrect type of ID column: must be UInt64, but it is String. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000001409b14a 4. ./build_docker/./src/Storages/StorageDictionary.cpp:61: DB::StorageDictionary::getNamesAndTypes(DB::DictionaryStructure const&, bool) @ 0x0000000038254d9f 5. ./build_docker/./src/Storages/StorageDictionary.cpp:0: DB::StorageDictionary::StorageDictionary(DB::StorageID const&, String const&, DB::DictionaryStructure const&, String const&, DB::StorageDictionary::Location, std::shared_ptr) @ 0x0000000038255de5 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageDictionary::StorageDictionary(DB::StorageID const&, Poco::AutoPtr, std::shared_ptr) @ 0x0000000038256789 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15007]&, std::shared_ptr&>(std::allocator, DB::StorageID&, Poco::AutoPtr&, std::shared_ptr&) @ 0x0000000038263e0a 8. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID&, Poco::AutoPtr&, std::shared_ptr&, void>(std::allocator const&, DB::StorageID&, Poco::AutoPtr&, std::shared_ptr&) @ 0x0000000038263b03 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000003825f560 10. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x0000000038308626 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348e414c 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 2025.10.23 23:51:40.898974 [ 3057 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:40.948151 [ 4674 ] {a17d3626-40fd-45b7-b6e8-20fbf522c698} executeQuery: Code: 36. DB::Exception: Incorrect type of ID column: must be UInt64, but it is UInt32. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59226) (comment: 03198_dictionary_validate_primary_key_type.sql) (in query: CREATE DICTIONARY `test_dictionary2` ( `n1` UInt32, `n2` UInt32 ) PRIMARY KEY n1 SOURCE(CLICKHOUSE(HOST 'localhost' PORT 9000 DB 'test_db' TABLE 'table_01' USER 'default')) LIFETIME(MIN 1 MAX 10) 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000001409b14a 4. ./build_docker/./src/Storages/StorageDictionary.cpp:61: DB::StorageDictionary::getNamesAndTypes(DB::DictionaryStructure const&, bool) @ 0x0000000038254d9f 5. ./build_docker/./src/Storages/StorageDictionary.cpp:0: DB::StorageDictionary::StorageDictionary(DB::StorageID const&, String const&, DB::DictionaryStructure const&, String const&, DB::StorageDictionary::Location, std::shared_ptr) @ 0x0000000038255de5 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageDictionary::StorageDictionary(DB::StorageID const&, Poco::AutoPtr, std::shared_ptr) @ 0x0000000038256789 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15007]&, std::shared_ptr&>(std::allocator, DB::StorageID&, Poco::AutoPtr&, std::shared_ptr&) @ 0x0000000038263e0a 8. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID&, Poco::AutoPtr&, std::shared_ptr&, void>(std::allocator const&, DB::StorageID&, Poco::AutoPtr&, std::shared_ptr&) @ 0x0000000038263b03 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000003825f560 10. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x0000000038308626 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348e414c 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 2025.10.23 23:51:40.949960 [ 4674 ] {a17d3626-40fd-45b7-b6e8-20fbf522c698} TCPHandler: Code: 36. DB::Exception: Incorrect type of ID column: must be UInt64, but it is UInt32. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000001409b14a 4. ./build_docker/./src/Storages/StorageDictionary.cpp:61: DB::StorageDictionary::getNamesAndTypes(DB::DictionaryStructure const&, bool) @ 0x0000000038254d9f 5. ./build_docker/./src/Storages/StorageDictionary.cpp:0: DB::StorageDictionary::StorageDictionary(DB::StorageID const&, String const&, DB::DictionaryStructure const&, String const&, DB::StorageDictionary::Location, std::shared_ptr) @ 0x0000000038255de5 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageDictionary::StorageDictionary(DB::StorageID const&, Poco::AutoPtr, std::shared_ptr) @ 0x0000000038256789 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15007]&, std::shared_ptr&>(std::allocator, DB::StorageID&, Poco::AutoPtr&, std::shared_ptr&) @ 0x0000000038263e0a 8. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID&, Poco::AutoPtr&, std::shared_ptr&, void>(std::allocator const&, DB::StorageID&, Poco::AutoPtr&, std::shared_ptr&) @ 0x0000000038263b03 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000003825f560 10. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x0000000038308626 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348e414c 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 23. ? @ 0x00007f100c857ac3 24. ? @ 0x00007f100c8e9850 2025.10.23 23:51:40.984733 [ 3345 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:41.286529 [ 3124 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:41.616187 [ 3406 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:41.798572 [ 3098 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:41.830768 [ 3564 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:41.900249 [ 3551 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:41.985668 [ 3561 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:42.287604 [ 3556 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:42.617171 [ 3565 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:42.799630 [ 3566 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:42.838739 [ 3236 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:42.901440 [ 3207 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:42.986628 [ 3554 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:43.289241 [ 3547 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:43.618156 [ 3505 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:43.832802 [ 3503 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:43.842565 [ 3501 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:43.903048 [ 3500 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:43.988178 [ 3509 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:44.290401 [ 3363 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:44.619314 [ 3494 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:44.834174 [ 3479 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:44.843730 [ 3483 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:44.904804 [ 3489 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:44.989373 [ 3477 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:45.291372 [ 3465 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:45.620204 [ 3449 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:45.835339 [ 3429 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:45.844655 [ 3431 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:45.905809 [ 3423 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:45.990557 [ 3533 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:46.292650 [ 3428 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:46.621306 [ 3411 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:46.836209 [ 3407 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:46.845409 [ 3405 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:46.907081 [ 3416 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:46.991642 [ 3397 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:47.294397 [ 3394 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:47.622238 [ 3383 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:47.837491 [ 3369 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:47.846338 [ 3374 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:47.908825 [ 3375 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:47.993125 [ 3382 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:48.295976 [ 3326 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:48.623458 [ 3315 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:48.838894 [ 3338 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:48.847269 [ 3324 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:48.910278 [ 3332 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:48.994290 [ 3304 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:49.296983 [ 3355 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:49.624841 [ 3331 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:49.631396 [ 9453 ] {af719612-846d-49ac-a2bf-65be30a07f9a} executeQuery: Code: 53. DB::Exception: Cannot convert string '1.0' to type UInt8: In scope SELECT 1 = '1.0'. (TYPE_MISMATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:43234) (comment: 01311_comparison_with_constant_string.sql) (in query: -- it should work but it doesn't. SELECT 1 = '1.0';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&&) @ 0x000000000df4df8d 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:559: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357d8570 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357ce96d 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 @ 0x000000000ec47080 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ebfd66c 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 2025.10.23 23:51:49.633236 [ 9453 ] {af719612-846d-49ac-a2bf-65be30a07f9a} TCPHandler: Code: 53. DB::Exception: Cannot convert string '1.0' to type UInt8: In scope SELECT 1 = '1.0'. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&&) @ 0x000000000df4df8d 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:559: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357d8570 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357ce96d 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 @ 0x000000000ec47080 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ebfd66c 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 2025.10.23 23:51:49.840548 [ 3309 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:49.848532 [ 3311 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:49.911374 [ 3300 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:49.995215 [ 3302 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:50.298182 [ 3285 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:50.625677 [ 3280 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:50.841548 [ 3257 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:50.849473 [ 3261 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:50.912639 [ 3268 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:50.996216 [ 3264 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:51.299504 [ 3250 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:51.626437 [ 3259 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:51.842512 [ 3242 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:51.850332 [ 3240 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:51.914036 [ 3247 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:51.997230 [ 3241 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:52.300735 [ 3211 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:52.627477 [ 3199 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:52.774859 [ 9453 ] {6f100f9c-e125-4a0c-94f7-a981bf0f037b} executeQuery: Code: 32. DB::Exception: Attempt to read after eof: while converting '' to UInt8: In scope SELECT 0 = ''. (ATTEMPT_TO_READ_AFTER_EOF) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:43234) (comment: 01311_comparison_with_constant_string.sql) (in query: SELECT 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/IO/VarInt.cpp:13: DB::throwReadAfterEOF() @ 0x000000002020212c 5. ./src/IO/ReadHelpers.h:0: DB::SerializationNumber::deserializeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, bool) const @ 0x0000000032793a04 6. DB::SimpleTextSerialization::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000086246a6 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357d49cb 8. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357ce96d 9. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ec47080 10. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ebfd66c 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 12. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 17. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 20. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 2025.10.23 23:51:52.776943 [ 9453 ] {6f100f9c-e125-4a0c-94f7-a981bf0f037b} TCPHandler: Code: 32. DB::Exception: Attempt to read after eof: while converting '' to UInt8: In scope SELECT 0 = ''. (ATTEMPT_TO_READ_AFTER_EOF), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/IO/VarInt.cpp:13: DB::throwReadAfterEOF() @ 0x000000002020212c 5. ./src/IO/ReadHelpers.h:0: DB::SerializationNumber::deserializeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, bool) const @ 0x0000000032793a04 6. DB::SimpleTextSerialization::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000086246a6 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357d49cb 8. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357ce96d 9. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ec47080 10. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ebfd66c 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 12. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334b05b2 17. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 20. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 2025.10.23 23:51:52.844319 [ 3189 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:52.851673 [ 3186 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:52.915670 [ 3185 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:52.998483 [ 3194 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:53.301637 [ 3173 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:53.628451 [ 3169 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:53.845701 [ 3150 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:53.852866 [ 3133 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:53.917143 [ 3139 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:53.999537 [ 3147 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:54.302865 [ 3142 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:54.629311 [ 3118 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:54.771042 [ 4841 ] {2017c293-8432-44eb-9234-aeea9368e0ef} executeQuery: Code: 43. DB::Exception: Second argument for function addSeconds must be a number. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:43280) (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. DB::FunctionDateOrDateTimeAddInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b8b04e9 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083d29bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60aa37 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b609cba 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60b9ac 9. DB::FunctionBinaryArithmetic::executeDateTimeIntervalPlusMinus(std::vector> const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&) const @ 0x000000001a094c84 10. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a091e09 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 12. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 14. DB::IExecutableFunction::defaultImplementationForNulls(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b6008d9 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffbf4 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 18. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000003324d830 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000033248983 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003b82b8f7 21. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:0: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000003bdff695 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::(anonymous namespace)::createComputeAliasColumnsStep(std::unordered_map, std::equal_to, std::allocator>>&, DB::DataStream const&) @ 0x0000000034da01d2 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000034d83747 24. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1777: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d67094 25. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0b8de 26. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cfd8b2 27. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034cf6172 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5bf1 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:51:54.787050 [ 4841 ] {2017c293-8432-44eb-9234-aeea9368e0ef} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. DB::FunctionDateOrDateTimeAddInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b8b04e9 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083d29bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60aa37 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b609cba 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b60b9ac 9. DB::FunctionBinaryArithmetic::executeDateTimeIntervalPlusMinus(std::vector> const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&) const @ 0x000000001a094c84 10. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a091e09 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000837d9c2 12. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083d58bb 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffcb1 14. DB::IExecutableFunction::defaultImplementationForNulls(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b6008d9 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5ffbf4 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b601c7f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b607a5e 18. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000003324d830 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000033248983 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003b82b8f7 21. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:0: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000003bdff695 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::(anonymous namespace)::createComputeAliasColumnsStep(std::unordered_map, std::equal_to, std::allocator>>&, DB::DataStream const&) @ 0x0000000034da01d2 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000034d83747 24. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1777: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000034d67094 25. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034d0b8de 26. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034cfd8b2 27. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034cf6172 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5bf1 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 2025.10.23 23:51:54.846819 [ 3119 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:54.853581 [ 3157 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:54.918031 [ 3116 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:55.000535 [ 3114 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:55.304272 [ 3106 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:55.630315 [ 3122 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:55.847846 [ 3100 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:55.854351 [ 3091 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:55.918901 [ 3082 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:56.001864 [ 3076 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:56.305348 [ 3072 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:56.631454 [ 3081 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:56.848936 [ 3056 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:56.855481 [ 3060 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:56.971666 [ 3062 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:57.003138 [ 3396 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:57.306408 [ 3291 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:57.632642 [ 3329 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:57.850092 [ 3562 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:57.856917 [ 3061 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:57.973132 [ 3201 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:58.004327 [ 3542 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:58.307596 [ 3529 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:58.633704 [ 3532 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:58.851368 [ 3516 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:58.857833 [ 3547 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:58.974122 [ 3515 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:59.005472 [ 3523 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:59.309348 [ 3501 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:59.634640 [ 3479 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:59.852569 [ 3489 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:59.858897 [ 3512 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:59.914904 [ 7760 ] {d6160796-3fc5-46b1-a64e-549eac829b3d} executeQuery: Code: 80. DB::Exception: Cannot MATERIALIZE TTL as there is no TTL set for table test_15.ttl (a19a8fb8-1633-41ed-b145-f0adc6e177ff). (INCORRECT_QUERY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44432) (comment: 01070_materialize_ttl.sql) (in query: alter table ttl materialize ttl;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:222: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348697af 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003485e550 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 2025.10.23 23:51:59.916486 [ 7760 ] {d6160796-3fc5-46b1-a64e-549eac829b3d} TCPHandler: Code: 80. DB::Exception: Cannot MATERIALIZE TTL as there is no TTL set for table test_15.ttl (a19a8fb8-1633-41ed-b145-f0adc6e177ff). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:222: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348697af 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003485e550 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 2025.10.23 23:51:59.975035 [ 3472 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:00.006382 [ 3480 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:00.118611 [ 7760 ] {e57cb480-beea-4172-9d65-dc6ee51f4bfa} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44432) (comment: 01070_materialize_ttl.sql) (in query: -- TTL should not be applied select * from ttl 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:52:00.126886 [ 7760 ] {e57cb480-beea-4172-9d65-dc6ee51f4bfa} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 2025.10.23 23:52:00.310656 [ 3478 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:00.395868 [ 32132 ] {10aa68af-5a2b-4f8e-ae38-854fa6d1cf9d} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44448) (comment: 01785_dictionary_element_count.sql) (in query: DROP DICTIONARY 01785_db.simple_key_flat_dictionary;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349417ab 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:52:00.398628 [ 32132 ] {10aa68af-5a2b-4f8e-ae38-854fa6d1cf9d} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349417ab 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000034939c7f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003493717d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:52:00.485744 [ 9453 ] {ebd1557b-9e8e-4aef-8549-9cbf91f13b99} executeQuery: Code: 57. DB::Exception: Table test_1.derived_metrics_local already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44426) (comment: 01506_ttl_same_with_order_by.sql) (in query: CREATE TABLE derived_metrics_local (`timestamp` DateTime, `bytes` UInt64) ENGINE = MergeTree PARTITION BY toYYYYMMDD(timestamp) ORDER BY (toStartOfHour(timestamp), timestamp) TTL toStartOfHour(timestamp) + toIntervalHour(1) SETTINGS min_bytes_for_wide_part = 0, index_granularity = 36496, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 34, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 316966709, compact_parts_max_granules_to_buffer = 20, compact_parts_merge_max_bytes_to_prefetch_part = 17133928, merge_max_block_size = 10510, old_parts_lifetime = 175., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 139733078, index_granularity_bytes = 20085745, concurrent_part_removal_threshold = 14, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 62858, primary_key_compress_block_size = 24799), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:52:00.489212 [ 9453 ] {ebd1557b-9e8e-4aef-8549-9cbf91f13b99} TCPHandler: Code: 57. DB::Exception: Table test_1.derived_metrics_local already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000838466d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348eb2d4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:52:00.635735 [ 3466 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:00.853505 [ 3447 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:00.859947 [ 3456 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:01.002283 [ 3446 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:01.007162 [ 3423 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:01.311966 [ 3436 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:01.636789 [ 3415 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:01.854813 [ 3393 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:01.860815 [ 3405 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:02.003315 [ 3404 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:02.008240 [ 3408 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:02.312977 [ 3390 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:02.637742 [ 3388 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:02.855929 [ 3374 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:02.861555 [ 3368 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:03.004423 [ 3360 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:03.009023 [ 3382 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:03.313928 [ 3326 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:03.350287 [ 9453 ] {6753e3c8-c205-4b48-8bcb-27ba40f7d944} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44490) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:03.350333 [ 32709 ] {dee7f052-c123-4f71-baf6-3696dfb00617} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44580) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:03.350402 [ 32693 ] {3ccf65dc-2992-4f11-8e7d-e2dfbe3e8456} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44522) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:03.350415 [ 32707 ] {ab8b33a9-7c7f-4b02-91b0-de5e09e2d8e2} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44574) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:03.352758 [ 32709 ] {dee7f052-c123-4f71-baf6-3696dfb00617} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:03.353243 [ 32707 ] {ab8b33a9-7c7f-4b02-91b0-de5e09e2d8e2} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:03.356119 [ 9453 ] {6753e3c8-c205-4b48-8bcb-27ba40f7d944} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:03.359098 [ 32693 ] {3ccf65dc-2992-4f11-8e7d-e2dfbe3e8456} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:03.638656 [ 3361 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:03.707523 [ 3894 ] {19dcfa88-192f-4679-a60b-6b5e3f4fb3fc} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44582) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:03.710446 [ 3894 ] {19dcfa88-192f-4679-a60b-6b5e3f4fb3fc} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:03.707528 [ 32689 ] {b436584a-0501-4f20-8bbb-adeb38c63cb0} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44510) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:03.714360 [ 32689 ] {b436584a-0501-4f20-8bbb-adeb38c63cb0} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:03.804124 [ 32698 ] {456a9c27-911f-4600-9499-d3d3ff19209c} executeQuery: Code: 394. DB::Exception: Query '456a9c27-911f-4600-9499-d3d3ff19209c' is killed in pending state. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44548) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:03.826389 [ 32698 ] {456a9c27-911f-4600-9499-d3d3ff19209c} TCPHandler: Code: 394. DB::Exception: Query '456a9c27-911f-4600-9499-d3d3ff19209c' is killed in pending state. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:03.856853 [ 3330 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:03.864156 [ 3332 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:04.005368 [ 3303 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:04.009804 [ 3297 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:04.251351 [ 32702 ] {b354087f-ca2d-4c85-b5ee-e64cf99b15d5} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44780) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:04.253854 [ 32702 ] {b354087f-ca2d-4c85-b5ee-e64cf99b15d5} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:04.314980 [ 3301 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:04.389766 [ 4799 ] {2abf56bc-ee7a-4411-95ab-7bf9bb9dee04} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44628) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:04.392502 [ 4799 ] {2abf56bc-ee7a-4411-95ab-7bf9bb9dee04} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:04.490365 [ 32707 ] {feb7d169-442e-4e7b-9df2-f0fc60b03b76} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44770) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:04.492982 [ 32707 ] {feb7d169-442e-4e7b-9df2-f0fc60b03b76} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:04.533230 [ 32717 ] {c8d0bbcb-169d-4394-a6c6-61fc9b9ff72d} executeQuery: Code: 394. DB::Exception: Query 'c8d0bbcb-169d-4394-a6c6-61fc9b9ff72d' is killed in pending state. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44816) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:04.540001 [ 32717 ] {c8d0bbcb-169d-4394-a6c6-61fc9b9ff72d} TCPHandler: Code: 394. DB::Exception: Query 'c8d0bbcb-169d-4394-a6c6-61fc9b9ff72d' is killed in pending state. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:04.644211 [ 3311 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:04.673636 [ 32709 ] {7b4e45cb-f2c6-4cf5-9dca-0de0c122e0ae} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44794) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:04.675921 [ 32709 ] {7b4e45cb-f2c6-4cf5-9dca-0de0c122e0ae} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:04.725099 [ 32689 ] {571c4000-76e2-41ed-997b-5163e07b931d} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44890) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:04.772969 [ 4674 ] {7d50463b-bd81-434c-a0ad-7f7ad585b0e0} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44878) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:04.775383 [ 4674 ] {7d50463b-bd81-434c-a0ad-7f7ad585b0e0} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:04.784646 [ 32707 ] {8a47aab2-fb03-4f9d-9aa9-342ec1907355} executeQuery: Code: 394. DB::Exception: Query '8a47aab2-fb03-4f9d-9aa9-342ec1907355' is killed in pending state. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44922) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:04.786044 [ 32711 ] {b906af0b-cfa9-4ee8-916e-1271c3e083e8} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44594) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aedf669 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:52:04.786153 [ 32714 ] {a01aa7b7-e1de-4e19-b647-7bf04496e39c} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44608) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aedf669 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:52:04.787676 [ 32707 ] {8a47aab2-fb03-4f9d-9aa9-342ec1907355} TCPHandler: Code: 394. DB::Exception: Query '8a47aab2-fb03-4f9d-9aa9-342ec1907355' is killed in pending state. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:04.795911 [ 32689 ] {571c4000-76e2-41ed-997b-5163e07b931d} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:04.799871 [ 32711 ] {b906af0b-cfa9-4ee8-916e-1271c3e083e8} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aedf669 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:52:04.804535 [ 32714 ] {a01aa7b7-e1de-4e19-b647-7bf04496e39c} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aedf669 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:52:04.859131 [ 3308 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:04.864850 [ 3300 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:05.006727 [ 3293 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:05.010634 [ 3299 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:05.161301 [ 32716 ] {bc2ea21f-bf1c-4cfb-b4ab-8288fe61cff4} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44930) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:05.163582 [ 32716 ] {bc2ea21f-bf1c-4cfb-b4ab-8288fe61cff4} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:05.187499 [ 32702 ] {2d570944-c0b5-48ee-845a-ecda8ed4b5b6} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:55088) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:05.189816 [ 32702 ] {2d570944-c0b5-48ee-845a-ecda8ed4b5b6} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:05.290394 [ 32707 ] {3ec64f01-1ed2-4f58-9b07-841bc50c7ed3} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:55090) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:05.361434 [ 32707 ] {3ec64f01-1ed2-4f58-9b07-841bc50c7ed3} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:05.388396 [ 3288 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:05.471311 [ 32709 ] {1b62bdbf-624b-4706-a66a-d66fc2f8b31f} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:55104) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:05.473644 [ 32709 ] {1b62bdbf-624b-4706-a66a-d66fc2f8b31f} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:05.511561 [ 9453 ] {9f390ef5-a8d5-462d-8028-ffceb1e9140e} executeQuery: Code: 394. DB::Exception: Query '9f390ef5-a8d5-462d-8028-ffceb1e9140e' is killed in pending state. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:55158) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:05.514822 [ 9453 ] {9f390ef5-a8d5-462d-8028-ffceb1e9140e} TCPHandler: Code: 394. DB::Exception: Query '9f390ef5-a8d5-462d-8028-ffceb1e9140e' is killed in pending state. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:05.644965 [ 3281 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:05.755508 [ 32695 ] {9b8e2acd-f6b0-45d2-950e-d50e6c134ae0} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:55208) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aedf669 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:52:05.761635 [ 32695 ] {9b8e2acd-f6b0-45d2-950e-d50e6c134ae0} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aedf669 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:52:05.765755 [ 4674 ] {febafdc9-4bab-4690-83be-f0867f9d1e3b} executeQuery: Code: 394. DB::Exception: Query 'febafdc9-4bab-4690-83be-f0867f9d1e3b' is killed in pending state. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:55174) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:05.766368 [ 32712 ] {7c6ca1c1-4cbc-499d-82d6-07d4b1967ff5} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:55134) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:05.768719 [ 32712 ] {7c6ca1c1-4cbc-499d-82d6-07d4b1967ff5} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:05.784167 [ 4674 ] {febafdc9-4bab-4690-83be-f0867f9d1e3b} TCPHandler: Code: 394. DB::Exception: Query 'febafdc9-4bab-4690-83be-f0867f9d1e3b' is killed in pending state. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:05.860124 [ 3272 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:05.865463 [ 3276 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:05.879994 [ 32698 ] {8083a1ce-a75a-412f-946f-ff034f3029b3} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:55220) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:05.882526 [ 32698 ] {8083a1ce-a75a-412f-946f-ff034f3029b3} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:05.989121 [ 9453 ] {5587e873-e8a6-4df5-949a-c9d30be3a0bb} executeQuery: Code: 394. DB::Exception: Query '5587e873-e8a6-4df5-949a-c9d30be3a0bb' is killed in pending state. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:55230) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:05.995915 [ 9453 ] {5587e873-e8a6-4df5-949a-c9d30be3a0bb} TCPHandler: Code: 394. DB::Exception: Query '5587e873-e8a6-4df5-949a-c9d30be3a0bb' is killed in pending state. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:05.997987 [ 32701 ] {5c2a9cea-c392-4853-a3da-008c46bb8ee2} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44778) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003aea508f 7. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee70d2 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:06.006739 [ 32690 ] {db7c1d24-9de6-4d77-b2f8-deea16cf574c} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:55264) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:06.011419 [ 3295 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:06.011818 [ 3274 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:06.020024 [ 32690 ] {db7c1d24-9de6-4d77-b2f8-deea16cf574c} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:06.031889 [ 32701 ] {5c2a9cea-c392-4853-a3da-008c46bb8ee2} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003aea508f 7. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee70d2 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:06.054316 [ 32711 ] {00e82f03-393c-4407-acb0-faed21367090} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:55226) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:06.057189 [ 32711 ] {00e82f03-393c-4407-acb0-faed21367090} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:06.128147 [ 32689 ] {94aa0ae0-186e-4d03-98ca-b9a8bdec1fe8} executeQuery: Code: 394. DB::Exception: Query '94aa0ae0-186e-4d03-98ca-b9a8bdec1fe8' is killed in pending state. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:55242) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:06.151370 [ 32689 ] {94aa0ae0-186e-4d03-98ca-b9a8bdec1fe8} TCPHandler: Code: 394. DB::Exception: Query '94aa0ae0-186e-4d03-98ca-b9a8bdec1fe8' is killed in pending state. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:06.232353 [ 32711 ] {6a2253c1-15c8-4c11-944b-7a85aa74282d} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:55326) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aedf669 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:52:06.239119 [ 32711 ] {6a2253c1-15c8-4c11-944b-7a85aa74282d} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aedf669 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:52:06.308253 [ 32693 ] {6a7af8c0-d0db-440e-abf3-8cd80f5047bc} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:55306) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:06.323932 [ 32693 ] {6a7af8c0-d0db-440e-abf3-8cd80f5047bc} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:06.389271 [ 3271 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:06.645687 [ 3243 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:06.646461 [ 32690 ] {2e8454fa-fe4e-40c4-9e20-22db0d484f2c} executeQuery: Code: 394. DB::Exception: Query '2e8454fa-fe4e-40c4-9e20-22db0d484f2c' is killed in pending state. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:55350) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:06.653444 [ 32690 ] {2e8454fa-fe4e-40c4-9e20-22db0d484f2c} TCPHandler: Code: 394. DB::Exception: Query '2e8454fa-fe4e-40c4-9e20-22db0d484f2c' is killed in pending state. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:06.654850 [ 32689 ] {ad84e951-f68c-46a8-bce8-a29f955304f3} executeQuery: Code: 394. DB::Exception: Query 'ad84e951-f68c-46a8-bce8-a29f955304f3' is killed in pending state. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:55380) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:06.657604 [ 32689 ] {ad84e951-f68c-46a8-bce8-a29f955304f3} TCPHandler: Code: 394. DB::Exception: Query 'ad84e951-f68c-46a8-bce8-a29f955304f3' is killed in pending state. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:06.728280 [ 32693 ] {b21bc9a8-0ecf-44f1-9ef0-6b83f01f0356} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:55388) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:06.743937 [ 32693 ] {b21bc9a8-0ecf-44f1-9ef0-6b83f01f0356} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:06.798794 [ 32714 ] {03658d11-34c4-4e8d-97a0-a9d771e14cbd} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:55392) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:06.826662 [ 32711 ] {d0aab4d5-8eae-4917-8766-c243ad157e1b} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:55396) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:06.828803 [ 32711 ] {d0aab4d5-8eae-4917-8766-c243ad157e1b} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:06.830895 [ 32714 ] {03658d11-34c4-4e8d-97a0-a9d771e14cbd} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:06.864293 [ 3249 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:06.868108 [ 3233 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:06.918320 [ 4674 ] {ba7d11d2-dbd6-4984-8235-6018c00024e3} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:55394) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:06.920566 [ 4674 ] {ba7d11d2-dbd6-4984-8235-6018c00024e3} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:07.012129 [ 3241 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:07.012703 [ 3231 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:07.192677 [ 32712 ] {22cb3dcc-c5d1-474a-9a21-c32bea5b2f60} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:55436) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:07.195123 [ 32712 ] {22cb3dcc-c5d1-474a-9a21-c32bea5b2f60} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:07.234397 [ 32698 ] {c3128b27-6192-415e-a6a6-b3e3bb7877b7} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:55410) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:07.236985 [ 32698 ] {c3128b27-6192-415e-a6a6-b3e3bb7877b7} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:07.289603 [ 32709 ] {157128a9-66c6-402d-a19f-87b4ce4363d0} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:55430) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:07.291994 [ 32709 ] {157128a9-66c6-402d-a19f-87b4ce4363d0} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:07.363659 [ 32717 ] {5c44ffd3-5982-4162-8b70-1998857b0691} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:55454) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:07.365995 [ 32717 ] {5c44ffd3-5982-4162-8b70-1998857b0691} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:07.392630 [ 3214 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:07.646387 [ 3225 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:07.701082 [ 32702 ] {11ca06b6-b869-4e58-a7e2-6938d903026a} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:55412) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:104: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3bd6 6. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 7. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 9. ? @ 0x00007f100c857ac3 10. ? @ 0x00007f100c8e9850 2025.10.23 23:52:07.731937 [ 32702 ] {11ca06b6-b869-4e58-a7e2-6938d903026a} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:104: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3bd6 6. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 7. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 9. ? @ 0x00007f100c857ac3 10. ? @ 0x00007f100c8e9850 2025.10.23 23:52:07.865095 [ 3210 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:07.868785 [ 3212 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:07.897633 [ 32709 ] {d646ceff-b696-42a2-8a41-b0face2fe810} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:55506) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aedf669 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:52:07.901289 [ 32709 ] {d646ceff-b696-42a2-8a41-b0face2fe810} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aedf669 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:52:07.952745 [ 9453 ] {8d8090ad-3bdc-43f4-a708-65ce12a229df} executeQuery: Code: 394. DB::Exception: Query '8d8090ad-3bdc-43f4-a708-65ce12a229df' is killed in pending state. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:55540) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:07.955620 [ 9453 ] {8d8090ad-3bdc-43f4-a708-65ce12a229df} TCPHandler: Code: 394. DB::Exception: Query '8d8090ad-3bdc-43f4-a708-65ce12a229df' is killed in pending state. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:08.013543 [ 3193 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:08.013973 [ 3199 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:08.341177 [ 32702 ] {87542bab-2a7a-4d17-8576-5d1011c605e7} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:55594) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:08.348306 [ 32702 ] {87542bab-2a7a-4d17-8576-5d1011c605e7} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:08.393685 [ 3175 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:08.503776 [ 32712 ] {e39dc1c3-091d-448a-812a-638766e60e9e} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:55644) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aedf669 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:52:08.523131 [ 32712 ] {e39dc1c3-091d-448a-812a-638766e60e9e} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aedf669 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:52:08.647076 [ 3166 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:08.867779 [ 3151 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:08.869451 [ 3148 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:09.014374 [ 3152 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:09.014771 [ 3147 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:09.096485 [ 4674 ] {1c8c9107-9cae-458a-8f32-bd13b4b46036} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:55722) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:09.099001 [ 4674 ] {1c8c9107-9cae-458a-8f32-bd13b4b46036} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:09.135445 [ 32695 ] {a65fcd84-1d06-45f6-a85b-064c05c7d0e0} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=754). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:55754) (comment: 00952_input_function.sh) (in query: SELECT * FROM input_function_table_2 FORMAT CSV), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:52:09.139618 [ 32695 ] {a65fcd84-1d06-45f6-a85b-064c05c7d0e0} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=754). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:52:09.394604 [ 3162 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:09.440211 [ 32701 ] {6dceed93-b30e-4737-9142-2afae93e6bbb} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:55794) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:09.442402 [ 32701 ] {6dceed93-b30e-4737-9142-2afae93e6bbb} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:09.452456 [ 32702 ] {f192bd18-063b-4b9c-bcb4-538a4b17938f} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:55816) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aedf669 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:52:09.454526 [ 32702 ] {f192bd18-063b-4b9c-bcb4-538a4b17938f} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aedf669 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:52:09.553105 [ 32695 ] {16e8039e-e3f2-48b0-9944-18a3f481455d} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:55852) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aedf669 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:52:09.564057 [ 32695 ] {16e8039e-e3f2-48b0-9944-18a3f481455d} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aedf669 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:52:09.623154 [ 32693 ] {96ebf05b-9e50-4f2e-aa10-028fe2694fa4} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:55824) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aedf669 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:52:09.623810 [ 32709 ] {aeaecf7e-b2cc-40bd-81f1-233dbeffc146} executeQuery: Code: 394. DB::Exception: Query 'aeaecf7e-b2cc-40bd-81f1-233dbeffc146' is killed in pending state. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:55862) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:09.626815 [ 32709 ] {aeaecf7e-b2cc-40bd-81f1-233dbeffc146} TCPHandler: Code: 394. DB::Exception: Query 'aeaecf7e-b2cc-40bd-81f1-233dbeffc146' is killed in pending state. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:09.647860 [ 3157 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:09.648027 [ 32693 ] {96ebf05b-9e50-4f2e-aa10-028fe2694fa4} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aedf669 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:52:09.868627 [ 3120 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:09.870175 [ 3130 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:09.915598 [ 32695 ] {58ac99bf-702b-443e-9c4c-58934cf877ce} executeQuery: Code: 394. DB::Exception: Query '58ac99bf-702b-443e-9c4c-58934cf877ce' is killed in pending state. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:55920) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:09.918759 [ 32695 ] {58ac99bf-702b-443e-9c4c-58934cf877ce} TCPHandler: Code: 394. DB::Exception: Query '58ac99bf-702b-443e-9c4c-58934cf877ce' is killed in pending state. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:10.015362 [ 3113 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:10.015493 [ 3108 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:10.271658 [ 32689 ] {03dac505-8f4a-4fdf-850e-754a740ad348} executeQuery: Code: 394. DB::Exception: Query '03dac505-8f4a-4fdf-850e-754a740ad348' is killed in pending state. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:55944) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:10.274407 [ 32689 ] {03dac505-8f4a-4fdf-850e-754a740ad348} TCPHandler: Code: 394. DB::Exception: Query '03dac505-8f4a-4fdf-850e-754a740ad348' is killed in pending state. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:10.355948 [ 32711 ] {94de6dc6-1f1d-4c66-b03b-efb2a113f245} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=753). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:55966) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:52:10.395513 [ 3099 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:10.395971 [ 32711 ] {94de6dc6-1f1d-4c66-b03b-efb2a113f245} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=753). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:52:10.407093 [ 32714 ] {4ab90149-2328-4e44-af6d-db5316c30b37} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:55972) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:10.409306 [ 32701 ] {71409356-f4e6-4303-bcec-7a0df6ccd058} executeQuery: Code: 394. DB::Exception: Query '71409356-f4e6-4303-bcec-7a0df6ccd058' is killed in pending state. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:55982) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:10.420174 [ 32701 ] {71409356-f4e6-4303-bcec-7a0df6ccd058} TCPHandler: Code: 394. DB::Exception: Query '71409356-f4e6-4303-bcec-7a0df6ccd058' is killed in pending state. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:10.440002 [ 32714 ] {4ab90149-2328-4e44-af6d-db5316c30b37} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:10.637241 [ 32716 ] {4e982ae8-cfed-4d27-8332-da9b682e7d70} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56004) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:10.639426 [ 32716 ] {4e982ae8-cfed-4d27-8332-da9b682e7d70} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:10.642200 [ 32717 ] {4a9a32d0-be6f-40b8-a5c2-4624827a68af} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56018) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:10.643617 [ 32717 ] {4a9a32d0-be6f-40b8-a5c2-4624827a68af} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:10.648552 [ 3094 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:10.667501 [ 3894 ] {ecf1beda-e971-430d-af16-3d477363ad92} executeQuery: Code: 394. DB::Exception: Query 'ecf1beda-e971-430d-af16-3d477363ad92' is killed in pending state. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56032) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:10.676694 [ 3894 ] {ecf1beda-e971-430d-af16-3d477363ad92} TCPHandler: Code: 394. DB::Exception: Query 'ecf1beda-e971-430d-af16-3d477363ad92' is killed in pending state. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:10.733569 [ 32712 ] {7a4b7e5a-70ab-4170-a3d0-dc9a8ff1a1e3} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56000) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:10.742806 [ 32712 ] {7a4b7e5a-70ab-4170-a3d0-dc9a8ff1a1e3} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:10.869488 [ 3076 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:10.870924 [ 3075 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:10.997832 [ 32702 ] {a49f8c99-03df-4030-977f-69c601871cd0} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56086) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aedf669 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:52:11.017901 [ 32702 ] {a49f8c99-03df-4030-977f-69c601871cd0} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aedf669 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:52:11.018089 [ 3085 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:11.018101 [ 3084 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:11.273561 [ 4799 ] {23bad45d-93e2-4c1e-8078-61558c0d112c} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56108) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aedf669 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:52:11.383950 [ 4799 ] {23bad45d-93e2-4c1e-8078-61558c0d112c} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aedf669 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:52:11.396423 [ 3092 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:11.396605 [ 7760 ] {8cda4681-5a49-49a7-b469-d08f0c45c9f0} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56106) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:11.398702 [ 7760 ] {8cda4681-5a49-49a7-b469-d08f0c45c9f0} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:11.492886 [ 32712 ] {527d0ec9-2ef4-4491-b059-43ec8fb63876} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56134) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:11.500196 [ 32712 ] {527d0ec9-2ef4-4491-b059-43ec8fb63876} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:11.532917 [ 32709 ] {7d13d192-df5d-46b9-aad1-883db6e287c1} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56166) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:11.541001 [ 32709 ] {7d13d192-df5d-46b9-aad1-883db6e287c1} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:11.562357 [ 3894 ] {5f9b9d95-c00c-44b7-bf05-1d4d747fc414} executeQuery: Code: 394. DB::Exception: Query '5f9b9d95-c00c-44b7-bf05-1d4d747fc414' is killed in pending state. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56156) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:11.564922 [ 3894 ] {5f9b9d95-c00c-44b7-bf05-1d4d747fc414} TCPHandler: Code: 394. DB::Exception: Query '5f9b9d95-c00c-44b7-bf05-1d4d747fc414' is killed in pending state. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:11.566096 [ 9453 ] {a545014b-09c1-4a51-9531-65647e86b40b} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56178) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:11.567590 [ 9453 ] {a545014b-09c1-4a51-9531-65647e86b40b} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:11.599659 [ 32717 ] {08293fa7-b5b2-47ff-8641-6751b71166dc} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56150) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:11.602165 [ 32717 ] {08293fa7-b5b2-47ff-8641-6751b71166dc} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:11.679276 [ 3060 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:11.870341 [ 3067 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:11.871591 [ 3427 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:11.902028 [ 7760 ] {62ae6f7c-65d7-40e9-9b87-dc588ff29e78} executeQuery: Code: 394. DB::Exception: Query '62ae6f7c-65d7-40e9-9b87-dc588ff29e78' is killed in pending state. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56220) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:11.905509 [ 7760 ] {62ae6f7c-65d7-40e9-9b87-dc588ff29e78} TCPHandler: Code: 394. DB::Exception: Query '62ae6f7c-65d7-40e9-9b87-dc588ff29e78' is killed in pending state. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:11.941825 [ 3894 ] {23a813c0-3573-4fb3-a8cc-1260200aeda0} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56238) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aedf669 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:52:11.949476 [ 3894 ] {23a813c0-3573-4fb3-a8cc-1260200aeda0} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aedf669 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:52:11.973337 [ 4799 ] {417426e2-f046-4498-b39d-0aa11d1c3e16} executeQuery: Code: 394. DB::Exception: Query '417426e2-f046-4498-b39d-0aa11d1c3e16' is killed in pending state. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56206) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:12.005311 [ 4674 ] {d644060a-4569-4ecf-94cd-9c39249f398f} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56226) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:12.007977 [ 4674 ] {d644060a-4569-4ecf-94cd-9c39249f398f} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:12.019067 [ 3054 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:12.019282 [ 3057 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:12.059114 [ 4799 ] {417426e2-f046-4498-b39d-0aa11d1c3e16} TCPHandler: Code: 394. DB::Exception: Query '417426e2-f046-4498-b39d-0aa11d1c3e16' is killed in pending state. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:12.397278 [ 3265 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:12.430247 [ 32701 ] {6abc15d4-fad0-434f-bc7c-1a2f5aab7dc9} executeQuery: Code: 394. DB::Exception: Query '6abc15d4-fad0-434f-bc7c-1a2f5aab7dc9' is killed in pending state. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56312) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:12.450168 [ 32701 ] {6abc15d4-fad0-434f-bc7c-1a2f5aab7dc9} TCPHandler: Code: 394. DB::Exception: Query '6abc15d4-fad0-434f-bc7c-1a2f5aab7dc9' is killed in pending state. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:12.497707 [ 32714 ] {b971fb52-f846-44c8-a5a6-e67420ac1b76} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56310) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:12.516187 [ 32714 ] {b971fb52-f846-44c8-a5a6-e67420ac1b76} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:12.680218 [ 3071 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:12.777422 [ 32693 ] {22d6dba9-dcf2-4b65-886f-ee55ede2bb61} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56342) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:12.779934 [ 32693 ] {22d6dba9-dcf2-4b65-886f-ee55ede2bb61} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:12.871143 [ 3174 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:12.872601 [ 3406 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:12.984962 [ 32711 ] {8d8d5ec2-c6d2-4db8-a6ca-aa1865d936fd} executeQuery: Code: 394. DB::Exception: Query '8d8d5ec2-c6d2-4db8-a6ca-aa1865d936fd' is killed in pending state. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56384) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:12.999969 [ 32711 ] {8d8d5ec2-c6d2-4db8-a6ca-aa1865d936fd} TCPHandler: Code: 394. DB::Exception: Query '8d8d5ec2-c6d2-4db8-a6ca-aa1865d936fd' is killed in pending state. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:13.020037 [ 3562 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:13.020045 [ 3061 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:13.122135 [ 32689 ] {2798fb87-7db9-4df4-8f5c-f5e13b5ab3c9} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56406) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aedf669 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:52:13.130452 [ 32689 ] {2798fb87-7db9-4df4-8f5c-f5e13b5ab3c9} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aedf669 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:52:13.348244 [ 32712 ] {fa33b908-9636-40f4-bdf3-385e3f832833} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56430) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:13.350747 [ 32712 ] {fa33b908-9636-40f4-bdf3-385e3f832833} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:13.398818 [ 3544 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:13.437775 [ 32693 ] {014bd21b-61aa-4281-a91e-5f0e207e0467} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56446) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:13.440873 [ 32693 ] {014bd21b-61aa-4281-a91e-5f0e207e0467} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:13.679357 [ 32709 ] {47dd895f-3ffd-46f4-ad40-2503d1e9061c} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56488) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:13.680915 [ 3556 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:13.698824 [ 32709 ] {47dd895f-3ffd-46f4-ad40-2503d1e9061c} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:13.718396 [ 32689 ] {52aa456e-1558-4825-840c-73ee859cc4a6} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56464) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:13.731053 [ 32689 ] {52aa456e-1558-4825-840c-73ee859cc4a6} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:13.736759 [ 32716 ] {de660098-2822-4b42-9889-e33d6ab95819} executeQuery: Code: 394. DB::Exception: Query 'de660098-2822-4b42-9889-e33d6ab95819' is killed in pending state. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56492) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:13.739627 [ 32716 ] {de660098-2822-4b42-9889-e33d6ab95819} TCPHandler: Code: 394. DB::Exception: Query 'de660098-2822-4b42-9889-e33d6ab95819' is killed in pending state. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:13.790225 [ 32695 ] {889160f6-965e-4d96-bb23-37bda5da5594} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56476) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:13.794135 [ 32695 ] {889160f6-965e-4d96-bb23-37bda5da5594} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:13.872608 [ 3529 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:13.873566 [ 3541 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:14.020884 [ 3543 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:14.020982 [ 3548 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:14.087989 [ 2903 ] {04eedb7c-1ca2-4f15-86a3-057502627ab0} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56592) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:14.089945 [ 32709 ] {e810507e-aa4d-4ad6-83e8-338efb0e1a8e} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56580) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aedf669 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:52:14.091615 [ 2903 ] {04eedb7c-1ca2-4f15-86a3-057502627ab0} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:14.114499 [ 32709 ] {e810507e-aa4d-4ad6-83e8-338efb0e1a8e} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aedf669 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:52:14.153018 [ 4674 ] {cde395a8-5c0d-4ada-8f0a-aa6d258f1c08} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56564) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:14.156025 [ 4674 ] {cde395a8-5c0d-4ada-8f0a-aa6d258f1c08} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:14.311834 [ 32695 ] {69441c2e-98af-4139-9e50-61cb400b019a} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56602) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003aea508f 7. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee70d2 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:14.314279 [ 32695 ] {69441c2e-98af-4139-9e50-61cb400b019a} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003aea508f 7. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee70d2 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:14.399798 [ 3549 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:14.489564 [ 3894 ] {4e8ffa06-39a9-4d25-b24c-6b5ec77520c4} executeQuery: Code: 394. DB::Exception: Query '4e8ffa06-39a9-4d25-b24c-6b5ec77520c4' is killed in pending state. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56648) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:14.492382 [ 3894 ] {4e8ffa06-39a9-4d25-b24c-6b5ec77520c4} TCPHandler: Code: 394. DB::Exception: Query '4e8ffa06-39a9-4d25-b24c-6b5ec77520c4' is killed in pending state. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:14.556226 [ 32717 ] {35d81750-92eb-4601-bf0c-0db273d00629} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56622) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:14.558728 [ 32717 ] {35d81750-92eb-4601-bf0c-0db273d00629} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:14.681548 [ 3521 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:14.751561 [ 32716 ] {407be3e6-9142-41c8-a582-e7539e025685} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56660) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aedf669 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:52:14.769491 [ 32716 ] {407be3e6-9142-41c8-a582-e7539e025685} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aedf669 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:52:14.808167 [ 9453 ] {23903898-5e64-4098-8102-454bb894b5d2} executeQuery: Code: 394. DB::Exception: Query '23903898-5e64-4098-8102-454bb894b5d2' is killed in pending state. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56670) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:14.810700 [ 9453 ] {23903898-5e64-4098-8102-454bb894b5d2} TCPHandler: Code: 394. DB::Exception: Query '23903898-5e64-4098-8102-454bb894b5d2' is killed in pending state. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:14.873592 [ 3511 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:14.874258 [ 3518 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:15.023950 [ 3520 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:15.026036 [ 3507 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:15.145811 [ 4674 ] {9fe6ee8c-e097-4d08-b278-0083d897d286} executeQuery: Code: 394. DB::Exception: Query '9fe6ee8c-e097-4d08-b278-0083d897d286' is killed in pending state. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56746) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:15.167413 [ 4674 ] {9fe6ee8c-e097-4d08-b278-0083d897d286} TCPHandler: Code: 394. DB::Exception: Query '9fe6ee8c-e097-4d08-b278-0083d897d286' is killed in pending state. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:15.400661 [ 3509 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:15.417916 [ 32711 ] {ea243e95-1dd3-40bd-94d8-8079a1d76411} executeQuery: Code: 394. DB::Exception: Query 'ea243e95-1dd3-40bd-94d8-8079a1d76411' is killed in pending state. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:36878) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:15.420679 [ 32711 ] {ea243e95-1dd3-40bd-94d8-8079a1d76411} TCPHandler: Code: 394. DB::Exception: Query 'ea243e95-1dd3-40bd-94d8-8079a1d76411' is killed in pending state. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:15.434700 [ 32690 ] {e0bba053-76b6-474c-8d05-ad7d72b4a325} executeQuery: Code: 394. DB::Exception: Query 'e0bba053-76b6-474c-8d05-ad7d72b4a325' is killed in pending state. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:36868) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:15.456192 [ 32690 ] {e0bba053-76b6-474c-8d05-ad7d72b4a325} TCPHandler: Code: 394. DB::Exception: Query 'e0bba053-76b6-474c-8d05-ad7d72b4a325' is killed in pending state. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:15.553494 [ 32712 ] {9866d0f9-c78a-44e5-8096-4c2c7aef1883} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=750). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:36916) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:52:15.558090 [ 32712 ] {9866d0f9-c78a-44e5-8096-4c2c7aef1883} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=750). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:52:15.603864 [ 32132 ] {a989196a-eaa8-44d3-b129-3ded47a8780b} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:50102) (comment: 00755_avg_value_size_hint_passing.sql) (in query: DROP DATABASE IF EXISTS test_bdnk79cs ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:52:15.616967 [ 32132 ] {a989196a-eaa8-44d3-b129-3ded47a8780b} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:15.653369 [ 32698 ] {953012e4-c5ee-47cd-af3b-e6b67d459353} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:36930) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:15.657805 [ 32695 ] {6707c945-5852-4cef-bf66-367e104f10e9} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:36928) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:15.661999 [ 32695 ] {6707c945-5852-4cef-bf66-367e104f10e9} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:15.665610 [ 32709 ] {1e17b0b8-69f5-47c1-a906-4eddbe6b645b} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:50118) (comment: 00755_avg_value_size_hint_passing.sql) (in query: DROP DATABASE IF EXISTS test_bdnk79cs ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:52:15.668340 [ 32709 ] {1e17b0b8-69f5-47c1-a906-4eddbe6b645b} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:15.682238 [ 3496 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:15.683769 [ 32698 ] {953012e4-c5ee-47cd-af3b-e6b67d459353} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:15.871302 [ 32717 ] {c4a933b1-4e44-4e9d-83b0-d609f78de469} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:36946) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aedf669 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:52:15.874591 [ 3388 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:15.874899 [ 3398 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:15.875272 [ 32717 ] {c4a933b1-4e44-4e9d-83b0-d609f78de469} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aedf669 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:52:16.004565 [ 32714 ] {1c35b901-2a5f-4588-a8de-7e9f29c9b1a2} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:36968) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:104: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3bd6 6. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 7. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 9. ? @ 0x00007f100c857ac3 10. ? @ 0x00007f100c8e9850 2025.10.23 23:52:16.006704 [ 32714 ] {1c35b901-2a5f-4588-a8de-7e9f29c9b1a2} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:104: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3bd6 6. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 7. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 9. ? @ 0x00007f100c857ac3 10. ? @ 0x00007f100c8e9850 2025.10.23 23:52:16.024769 [ 3402 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:16.026695 [ 3376 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:16.401551 [ 3374 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:16.683030 [ 3354 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:16.751251 [ 32693 ] {75aaa6ef-e2e9-4a05-8c95-8498effbaed9} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37074) (comment: 01600_multiple_left_join_with_aliases.sql) (in query: CREATE TABLE derived1 (`id1` UInt64, `d1` UInt64, `value1` UInt64) ENGINE = MergeTree PARTITION BY d1 ORDER BY (id1, d1) SETTINGS index_granularity = 23161, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 27, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 152617778, compact_parts_max_granules_to_buffer = 36, compact_parts_merge_max_bytes_to_prefetch_part = 14656735, merge_max_block_size = 16857, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 878952, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 2227107243, index_granularity_bytes = 7038437, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 50790, primary_key_compress_block_size = 31997), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x0000000039709f85 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>) @ 0x000000003a2e5f4a 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a2e404f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2d3063 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7b27a 12. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x0000000038308626 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348e414c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:52:16.754855 [ 32693 ] {75aaa6ef-e2e9-4a05-8c95-8498effbaed9} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x0000000039709f85 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>) @ 0x000000003a2e5f4a 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a2e404f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2d3063 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c7b27a 12. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x0000000038308626 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348e414c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348cfdab 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f76 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 25. ? @ 0x00007f100c857ac3 26. ? @ 0x00007f100c8e9850 2025.10.23 23:52:16.834663 [ 32712 ] {ba8b6656-905b-4fcf-939f-b80fb7702f11} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37086) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:16.837099 [ 32712 ] {ba8b6656-905b-4fcf-939f-b80fb7702f11} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:16.874813 [ 32709 ] {1556eec9-f343-44ca-a03b-da956c08fb54} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37100) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:16.877969 [ 32709 ] {1556eec9-f343-44ca-a03b-da956c08fb54} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:16.884700 [ 32717 ] {07963d8c-0f10-4c2e-99e1-ade78c2a7ed7} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37152) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:16.886959 [ 32717 ] {07963d8c-0f10-4c2e-99e1-ade78c2a7ed7} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:16.887773 [ 3344 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:16.896866 [ 3365 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:16.912072 [ 32689 ] {f03e3fe3-919e-4540-8b6d-889ada469b32} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37114) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:16.914399 [ 32689 ] {f03e3fe3-919e-4540-8b6d-889ada469b32} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:16.974355 [ 32698 ] {85a3ab8d-2c77-4e55-9674-672ca84e168c} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37138) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:16.976587 [ 32698 ] {85a3ab8d-2c77-4e55-9674-672ca84e168c} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:16.991350 [ 3894 ] {1e66bd9e-3cc2-4b21-8cb9-909e3daa4236} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37156) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:17.000040 [ 3894 ] {1e66bd9e-3cc2-4b21-8cb9-909e3daa4236} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:17.027340 [ 3373 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:17.031603 [ 3361 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:17.277543 [ 32702 ] {1c2d0c7c-fede-442f-bd17-a06ea9e12e3a} executeQuery: Code: 394. DB::Exception: Query '1c2d0c7c-fede-442f-bd17-a06ea9e12e3a' is killed in pending state. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37170) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:17.280775 [ 32702 ] {1c2d0c7c-fede-442f-bd17-a06ea9e12e3a} TCPHandler: Code: 394. DB::Exception: Query '1c2d0c7c-fede-442f-bd17-a06ea9e12e3a' is killed in pending state. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:17.300122 [ 9453 ] {a18e6d7b-08ee-4a50-b20b-768df737a4b2} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37166) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:17.302610 [ 9453 ] {a18e6d7b-08ee-4a50-b20b-768df737a4b2} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:17.378573 [ 32698 ] {5ff18793-9a14-4f0c-bf65-fc5530a97644} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37232) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:17.378736 [ 4674 ] {f9d6981c-9484-428f-9256-7ffa97b27f35} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37186) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:17.381179 [ 7760 ] {04e926b8-7498-4b2a-8ac1-d4bc9d44ba5d} executeQuery: Code: 394. DB::Exception: Query '04e926b8-7498-4b2a-8ac1-d4bc9d44ba5d' is killed in pending state. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37184) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:17.383576 [ 7760 ] {04e926b8-7498-4b2a-8ac1-d4bc9d44ba5d} TCPHandler: Code: 394. DB::Exception: Query '04e926b8-7498-4b2a-8ac1-d4bc9d44ba5d' is killed in pending state. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:17.384402 [ 32698 ] {5ff18793-9a14-4f0c-bf65-fc5530a97644} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:17.384613 [ 4674 ] {f9d6981c-9484-428f-9256-7ffa97b27f35} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:17.402323 [ 3313 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:17.683971 [ 3335 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:17.888752 [ 3340 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:17.897593 [ 3308 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:17.921605 [ 4674 ] {299345c0-0938-4e48-98ac-9217eda5b93d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=750). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37316) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:52:17.923569 [ 4674 ] {299345c0-0938-4e48-98ac-9217eda5b93d} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=750). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:52:18.028284 [ 3290 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:18.032546 [ 3293 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:18.341551 [ 2903 ] {3e2169a1-ce05-4250-b014-bf09712d50ca} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37368) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:18.343591 [ 2903 ] {3e2169a1-ce05-4250-b014-bf09712d50ca} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:18.346794 [ 32132 ] {b7cea6a7-1199-4e5b-81f9-02c3e808aaff} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37394) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:18.348802 [ 32132 ] {b7cea6a7-1199-4e5b-81f9-02c3e808aaff} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:18.351262 [ 32690 ] {d0ed9d3d-d19f-4b93-a486-d23132804dd0} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37414) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aedf669 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:52:18.374055 [ 32690 ] {d0ed9d3d-d19f-4b93-a486-d23132804dd0} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aedf669 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:52:18.403028 [ 3257 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:18.461527 [ 32689 ] {c65b3013-0447-4e35-8271-987023b11580} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37404) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:18.468060 [ 32689 ] {c65b3013-0447-4e35-8271-987023b11580} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:18.662511 [ 32695 ] {a74eba08-7e44-4e01-b2a7-75d1ca2322a5} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37442) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:18.683954 [ 32695 ] {a74eba08-7e44-4e01-b2a7-75d1ca2322a5} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:18.686048 [ 3264 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:18.889740 [ 3267 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:18.898254 [ 3251 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:19.029075 [ 3269 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:19.033383 [ 3243 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:19.166091 [ 3894 ] {7dd3662b-fd2d-48ab-b2d4-1737759b0931} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37512) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:19.171013 [ 3894 ] {7dd3662b-fd2d-48ab-b2d4-1737759b0931} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:19.403956 [ 3233 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:19.532749 [ 32712 ] {a389e6a0-f513-47d9-9097-4b0319ec7d4b} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37548) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:19.542534 [ 32712 ] {a389e6a0-f513-47d9-9097-4b0319ec7d4b} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:19.564156 [ 32709 ] {9c28dff9-f4d1-40f8-8360-6020bd5af834} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37576) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aedf669 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:52:19.612375 [ 32709 ] {9c28dff9-f4d1-40f8-8360-6020bd5af834} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aedf669 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:52:19.616694 [ 32701 ] {4231d1b1-fa74-4055-ab63-8815a42958eb} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37556) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:19.618877 [ 32701 ] {4231d1b1-fa74-4055-ab63-8815a42958eb} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:19.686849 [ 3239 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:19.879139 [ 32689 ] {06daea26-9b49-45d9-9b4b-fb53ad3608e3} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37632) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:19.881511 [ 32689 ] {06daea26-9b49-45d9-9b4b-fb53ad3608e3} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:19.890594 [ 3235 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:19.898884 [ 3230 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:19.904262 [ 3894 ] {721ff249-4486-4460-bb59-ba0056c695e4} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37612) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:19.906516 [ 3894 ] {721ff249-4486-4460-bb59-ba0056c695e4} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:19.967244 [ 4799 ] {49c88998-6e6c-4fa0-99f2-3ddf89217115} executeQuery: Code: 394. DB::Exception: Query '49c88998-6e6c-4fa0-99f2-3ddf89217115' is killed in pending state. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37660) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:20.030039 [ 3258 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:20.030723 [ 4799 ] {49c88998-6e6c-4fa0-99f2-3ddf89217115} TCPHandler: Code: 394. DB::Exception: Query '49c88998-6e6c-4fa0-99f2-3ddf89217115' is killed in pending state. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:20.042404 [ 32717 ] {b0e67d07-a5dd-4103-b4a8-330218db3d1b} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37668) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:20.067758 [ 32717 ] {b0e67d07-a5dd-4103-b4a8-330218db3d1b} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:20.067770 [ 3237 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:20.251191 [ 32702 ] {20f34d57-a486-43e5-81fa-5b51938ff9e2} executeQuery: Code: 394. DB::Exception: Query '20f34d57-a486-43e5-81fa-5b51938ff9e2' is killed in pending state. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37732) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:20.267077 [ 32702 ] {20f34d57-a486-43e5-81fa-5b51938ff9e2} TCPHandler: Code: 394. DB::Exception: Query '20f34d57-a486-43e5-81fa-5b51938ff9e2' is killed in pending state. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:20.272652 [ 4674 ] {ba09413e-371b-415f-bf65-0f268049babe} executeQuery: Code: 394. DB::Exception: Query 'ba09413e-371b-415f-bf65-0f268049babe' is killed in pending state. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37754) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:20.277175 [ 4674 ] {ba09413e-371b-415f-bf65-0f268049babe} TCPHandler: Code: 394. DB::Exception: Query 'ba09413e-371b-415f-bf65-0f268049babe' is killed in pending state. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:20.279289 [ 32707 ] {0d4d45ca-18ad-45fb-a57b-23f14d1bb6c2} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37736) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:20.283948 [ 32698 ] {509b1cb4-c1ef-43d6-8be5-619594a3f22b} executeQuery: Code: 394. DB::Exception: Query '509b1cb4-c1ef-43d6-8be5-619594a3f22b' is killed in pending state. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37710) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:20.285974 [ 32707 ] {0d4d45ca-18ad-45fb-a57b-23f14d1bb6c2} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:20.289491 [ 32709 ] {4387a0a8-fde5-492b-84b0-29c100015fa5} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37694) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:20.294226 [ 32709 ] {4387a0a8-fde5-492b-84b0-29c100015fa5} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:20.307972 [ 32698 ] {509b1cb4-c1ef-43d6-8be5-619594a3f22b} TCPHandler: Code: 394. DB::Exception: Query '509b1cb4-c1ef-43d6-8be5-619594a3f22b' is killed in pending state. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:20.404793 [ 3225 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:20.445580 [ 4841 ] {5200e65a-4b9f-4bf6-a8de-de234433a17e} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=750). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37778) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:52:20.468039 [ 4841 ] {5200e65a-4b9f-4bf6-a8de-de234433a17e} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=750). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:52:20.687643 [ 3190 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:20.765450 [ 32132 ] {89cc95fa-14ba-446b-8f0b-db5d0ad53c0b} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37832) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:20.776020 [ 32132 ] {89cc95fa-14ba-446b-8f0b-db5d0ad53c0b} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:20.870957 [ 32709 ] {4c347957-f60e-47fe-b44b-937cbec1c3bd} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=750). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37862) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:52:20.890017 [ 32709 ] {4c347957-f60e-47fe-b44b-937cbec1c3bd} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=750). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:52:20.891490 [ 3208 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:20.899677 [ 3193 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:21.030728 [ 3191 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:21.075684 [ 3238 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:21.211958 [ 32698 ] {8f2d5830-09b5-455a-bf0d-897beabd34b6} executeQuery: Code: 394. DB::Exception: Query '8f2d5830-09b5-455a-bf0d-897beabd34b6' is killed in pending state. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37904) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:21.222600 [ 32698 ] {8f2d5830-09b5-455a-bf0d-897beabd34b6} TCPHandler: Code: 394. DB::Exception: Query '8f2d5830-09b5-455a-bf0d-897beabd34b6' is killed in pending state. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:21.227886 [ 4841 ] {b377fd20-d94e-479c-a791-ee71dcd1c711} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37934) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:21.228987 [ 4674 ] {9fa4fcea-47d0-40d9-b4d6-e1bd6ac38290} executeQuery: Code: 394. DB::Exception: Query '9fa4fcea-47d0-40d9-b4d6-e1bd6ac38290' is killed in pending state. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37918) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:21.230411 [ 4841 ] {b377fd20-d94e-479c-a791-ee71dcd1c711} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:21.231954 [ 4674 ] {9fa4fcea-47d0-40d9-b4d6-e1bd6ac38290} TCPHandler: Code: 394. DB::Exception: Query '9fa4fcea-47d0-40d9-b4d6-e1bd6ac38290' is killed in pending state. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:21.299388 [ 7760 ] {ff0d6afc-b29d-46ff-9d85-f2eb45bffe9f} executeQuery: Code: 394. DB::Exception: Query 'ff0d6afc-b29d-46ff-9d85-f2eb45bffe9f' is killed in pending state. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37960) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:21.304856 [ 32711 ] {f426f8f6-ac40-4adc-8cad-a757fcaddb19} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37894) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:21.309684 [ 32711 ] {f426f8f6-ac40-4adc-8cad-a757fcaddb19} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:21.309726 [ 32132 ] {e8361cb7-1dc6-4302-be4c-5b830f974689} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37946) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aedf669 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:52:21.322348 [ 7760 ] {ff0d6afc-b29d-46ff-9d85-f2eb45bffe9f} TCPHandler: Code: 394. DB::Exception: Query 'ff0d6afc-b29d-46ff-9d85-f2eb45bffe9f' is killed in pending state. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:21.323991 [ 32132 ] {e8361cb7-1dc6-4302-be4c-5b830f974689} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aedf669 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:52:21.405588 [ 3192 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:21.691177 [ 3182 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:21.694472 [ 4674 ] {6ebd063b-a0f0-4d8e-96f5-aac96ce9dbcf} executeQuery: Code: 394. DB::Exception: Query '6ebd063b-a0f0-4d8e-96f5-aac96ce9dbcf' is killed in pending state. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38014) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:21.704240 [ 4674 ] {6ebd063b-a0f0-4d8e-96f5-aac96ce9dbcf} TCPHandler: Code: 394. DB::Exception: Query '6ebd063b-a0f0-4d8e-96f5-aac96ce9dbcf' is killed in pending state. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:21.892618 [ 3170 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:21.900787 [ 3165 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:22.031466 [ 3176 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:22.076457 [ 3171 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:22.406449 [ 3163 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:22.457663 [ 32701 ] {c860b607-5684-4be3-a5a2-c201b1de6e1e} executeQuery: Code: 394. DB::Exception: Query 'c860b607-5684-4be3-a5a2-c201b1de6e1e' is killed in pending state. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38102) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:22.461232 [ 32701 ] {c860b607-5684-4be3-a5a2-c201b1de6e1e} TCPHandler: Code: 394. DB::Exception: Query 'c860b607-5684-4be3-a5a2-c201b1de6e1e' is killed in pending state. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:22.664035 [ 3894 ] {631523f0-6130-4a71-88d3-8629c503c225} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38144) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:22.682906 [ 3894 ] {631523f0-6130-4a71-88d3-8629c503c225} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:22.693837 [ 3133 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:22.896293 [ 3152 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:22.901531 [ 3147 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:22.942733 [ 32690 ] {8267cbe9-ea00-41ed-9a26-63617f71abd1} executeQuery: Code: 394. DB::Exception: Query '8267cbe9-ea00-41ed-9a26-63617f71abd1' is killed in pending state. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38172) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:22.957941 [ 32690 ] {8267cbe9-ea00-41ed-9a26-63617f71abd1} TCPHandler: Code: 394. DB::Exception: Query '8267cbe9-ea00-41ed-9a26-63617f71abd1' is killed in pending state. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:23.035876 [ 3154 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:23.077277 [ 3134 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:23.319332 [ 32695 ] {c9ffb598-8499-4ab9-bdcd-cbb66bc2661d} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38224) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:23.325771 [ 32695 ] {c9ffb598-8499-4ab9-bdcd-cbb66bc2661d} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:23.374499 [ 3894 ] {590e60a1-871c-44e9-9f4e-138a103603b7} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38250) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:23.382766 [ 32701 ] {c97113c6-7e09-4bb4-9da9-8c6ba104c187} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38228) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:23.385215 [ 32701 ] {c97113c6-7e09-4bb4-9da9-8c6ba104c187} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:23.391931 [ 3894 ] {590e60a1-871c-44e9-9f4e-138a103603b7} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:23.407390 [ 3115 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:23.415258 [ 4799 ] {01babd09-f645-498f-bc1c-1aa5db610ab2} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38246) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:23.417911 [ 4799 ] {01babd09-f645-498f-bc1c-1aa5db610ab2} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:23.588816 [ 32698 ] {d7b44cbd-4ea9-40bc-981b-8bdb8e45d2d9} executeQuery: Code: 394. DB::Exception: Query 'd7b44cbd-4ea9-40bc-981b-8bdb8e45d2d9' is killed in pending state. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38280) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:23.590368 [ 32709 ] {79849353-e680-4d05-90dd-cfdb2adf26c7} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38274) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:23.592824 [ 32709 ] {79849353-e680-4d05-90dd-cfdb2adf26c7} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:23.592831 [ 32698 ] {d7b44cbd-4ea9-40bc-981b-8bdb8e45d2d9} TCPHandler: Code: 394. DB::Exception: Query 'd7b44cbd-4ea9-40bc-981b-8bdb8e45d2d9' is killed in pending state. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:23.603052 [ 32690 ] {2a2d56ee-5b8a-47d8-9667-8d415950f5c3} executeQuery: Code: 394. DB::Exception: Query '2a2d56ee-5b8a-47d8-9667-8d415950f5c3' is killed in pending state. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38252) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:23.610096 [ 32690 ] {2a2d56ee-5b8a-47d8-9667-8d415950f5c3} TCPHandler: Code: 394. DB::Exception: Query '2a2d56ee-5b8a-47d8-9667-8d415950f5c3' is killed in pending state. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:23.645888 [ 32707 ] {ee50d097-89fe-4415-a041-91229b405f06} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38296) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:23.656134 [ 32707 ] {ee50d097-89fe-4415-a041-91229b405f06} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:23.688147 [ 7760 ] {aaeb544b-1c5c-4afb-aa1c-fd4b2d845813} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38310) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:23.690359 [ 7760 ] {aaeb544b-1c5c-4afb-aa1c-fd4b2d845813} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:23.694523 [ 3140 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:23.897099 [ 3127 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:23.918972 [ 3159 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:24.036611 [ 3108 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:24.078195 [ 3107 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:24.408334 [ 3097 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:24.415348 [ 32707 ] {c2efec93-0848-4530-82ce-cdba34591a93} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38400) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:24.417529 [ 32707 ] {c2efec93-0848-4530-82ce-cdba34591a93} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:24.468789 [ 32702 ] {21603005-f008-4e0a-acd8-3056c112442e} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38416) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:24.485658 [ 32702 ] {21603005-f008-4e0a-acd8-3056c112442e} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:24.486025 [ 2903 ] {2ab7641e-910d-4f2c-9209-59fb79b04150} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38432) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:24.488477 [ 7760 ] {79c208cb-057e-4dea-b9ec-090978f07e45} executeQuery: Code: 394. DB::Exception: Query '79c208cb-057e-4dea-b9ec-090978f07e45' is killed in pending state. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38428) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:24.495978 [ 2903 ] {2ab7641e-910d-4f2c-9209-59fb79b04150} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:24.510029 [ 7760 ] {79c208cb-057e-4dea-b9ec-090978f07e45} TCPHandler: Code: 394. DB::Exception: Query '79c208cb-057e-4dea-b9ec-090978f07e45' is killed in pending state. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:24.565607 [ 32698 ] {3e090f13-e5a3-438c-9d77-c28e81f53831} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38388) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:24.573904 [ 32698 ] {3e090f13-e5a3-438c-9d77-c28e81f53831} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:24.610544 [ 32716 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x00000000315a10ad 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159da2f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b6b4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa269fb 10. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:24.691785 [ 4674 ] {f3574230-fe2b-4d62-8477-b64991dbc179} executeQuery: Code: 394. DB::Exception: Query 'f3574230-fe2b-4d62-8477-b64991dbc179' is killed in pending state. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38486) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:24.695251 [ 3076 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:24.712615 [ 4674 ] {f3574230-fe2b-4d62-8477-b64991dbc179} TCPHandler: Code: 394. DB::Exception: Query 'f3574230-fe2b-4d62-8477-b64991dbc179' is killed in pending state. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:24.752473 [ 32693 ] {a6bb1e46-b2ac-45d0-a879-8c9e91bd485b} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38526) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:24.754966 [ 32693 ] {a6bb1e46-b2ac-45d0-a879-8c9e91bd485b} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:24.897818 [ 3105 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:24.905019 [ 32701 ] {45b3b0e2-bc48-426a-b799-cd811a0429fc} executeQuery: Code: 394. DB::Exception: Query '45b3b0e2-bc48-426a-b799-cd811a0429fc' is killed in pending state. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38538) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:24.919900 [ 3072 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:24.926019 [ 32701 ] {45b3b0e2-bc48-426a-b799-cd811a0429fc} TCPHandler: Code: 394. DB::Exception: Query '45b3b0e2-bc48-426a-b799-cd811a0429fc' is killed in pending state. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:24.991168 [ 32716 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x00000000315a10ad 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159da2f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b6b4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa269fb 10. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:25.037308 [ 3081 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:25.079035 [ 3059 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:25.409113 [ 3444 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:25.449553 [ 32132 ] {85bd2a4a-9183-4b89-b88f-99d154cb546b} executeQuery: Code: 394. DB::Exception: Query '85bd2a4a-9183-4b89-b88f-99d154cb546b' is killed in pending state. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38278) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:25.475348 [ 32132 ] {85bd2a4a-9183-4b89-b88f-99d154cb546b} TCPHandler: Code: 394. DB::Exception: Query '85bd2a4a-9183-4b89-b88f-99d154cb546b' is killed in pending state. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:25.496503 [ 32712 ] {35217d92-9900-48f0-b36b-5dbf7386d78d} executeQuery: Code: 394. DB::Exception: Query '35217d92-9900-48f0-b36b-5dbf7386d78d' is killed in pending state. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38286) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:25.499355 [ 32712 ] {35217d92-9900-48f0-b36b-5dbf7386d78d} TCPHandler: Code: 394. DB::Exception: Query '35217d92-9900-48f0-b36b-5dbf7386d78d' is killed in pending state. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:25.503678 [ 4841 ] {5451b2d9-4a04-49c6-9d7b-077254f447e3} executeQuery: Code: 394. DB::Exception: Query '5451b2d9-4a04-49c6-9d7b-077254f447e3' is killed in pending state. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38262) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:25.527149 [ 4841 ] {5451b2d9-4a04-49c6-9d7b-077254f447e3} TCPHandler: Code: 394. DB::Exception: Query '5451b2d9-4a04-49c6-9d7b-077254f447e3' is killed in pending state. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:25.551351 [ 2903 ] {c61ae4d4-d6d2-46cc-af5e-576fd71f6dbc} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38246) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:25.553565 [ 2903 ] {c61ae4d4-d6d2-46cc-af5e-576fd71f6dbc} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:25.704895 [ 3443 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:25.898760 [ 3223 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:25.909127 [ 2903 ] {4cd153cc-58cb-43d3-a989-6459571d4df6} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38338) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:25.920690 [ 3265 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:25.927580 [ 2903 ] {4cd153cc-58cb-43d3-a989-6459571d4df6} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:25.933535 [ 32707 ] {3a728c48-01ac-41e8-9125-893d8987242a} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38360) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:25.940062 [ 32707 ] {3a728c48-01ac-41e8-9125-893d8987242a} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:25.961646 [ 32712 ] {e0e29d0e-2762-4770-9572-8b857dde373f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=751). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38390) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:52:25.968347 [ 32712 ] {e0e29d0e-2762-4770-9572-8b857dde373f} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=751). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:52:26.038339 [ 3291 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:26.057196 [ 32714 ] {577db430-0529-4c3f-9fba-55eb8f786242} executeQuery: Code: 394. DB::Exception: Query '577db430-0529-4c3f-9fba-55eb8f786242' is killed in pending state. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38366) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:26.125020 [ 3894 ] {557d5e5c-f99e-4277-b585-a117f2e5fc1d} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38398) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:26.127308 [ 3894 ] {557d5e5c-f99e-4277-b585-a117f2e5fc1d} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:26.136915 [ 32714 ] {577db430-0529-4c3f-9fba-55eb8f786242} TCPHandler: Code: 394. DB::Exception: Query '577db430-0529-4c3f-9fba-55eb8f786242' is killed in pending state. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:26.138768 [ 4841 ] {2585670f-b24b-4cd7-99ca-99d8be535820} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38410) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:26.158084 [ 4841 ] {2585670f-b24b-4cd7-99ca-99d8be535820} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:26.167081 [ 3124 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:26.409976 [ 3168 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:26.520264 [ 32693 ] {148ea1ed-1887-4820-823c-629705cb4928} executeQuery: Code: 394. DB::Exception: Query '148ea1ed-1887-4820-823c-629705cb4928' is killed in pending state. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38434) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:26.523295 [ 32693 ] {148ea1ed-1887-4820-823c-629705cb4928} TCPHandler: Code: 394. DB::Exception: Query '148ea1ed-1887-4820-823c-629705cb4928' is killed in pending state. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:26.566492 [ 32707 ] {a062796a-d69c-421d-9075-9172f35cf5af} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38454) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:26.568873 [ 32707 ] {a062796a-d69c-421d-9075-9172f35cf5af} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:26.705624 [ 3538 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:26.779584 [ 3894 ] {84466e52-2cca-46a3-968c-f521ff375b7c} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38530) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:26.782329 [ 3894 ] {84466e52-2cca-46a3-968c-f521ff375b7c} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:26.899662 [ 3213 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:26.921516 [ 3544 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:27.039040 [ 3550 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:27.065486 [ 32707 ] {2cb751a2-5f8e-480c-a48d-d3bbb08f56de} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38560) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aedf669 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:52:27.068327 [ 4841 ] {a7c78b41-5d09-4471-aa09-8e5411bfb3a9} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38586) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aedf669 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:52:27.080005 [ 32707 ] {2cb751a2-5f8e-480c-a48d-d3bbb08f56de} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aedf669 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:52:27.092371 [ 4841 ] {a7c78b41-5d09-4471-aa09-8e5411bfb3a9} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aedf669 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:52:27.168424 [ 3556 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:27.222318 [ 32709 ] {abcdf605-fb5d-45fd-87cd-1bd3dfb4f841} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38614) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:27.226862 [ 32709 ] {abcdf605-fb5d-45fd-87cd-1bd3dfb4f841} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:27.410971 [ 3529 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:27.518062 [ 32701 ] {704ab6e7-a2b1-4ebf-805f-f56514159e72} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=752). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38672) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:52:27.536017 [ 32701 ] {704ab6e7-a2b1-4ebf-805f-f56514159e72} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=752). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:52:27.706288 [ 3236 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:27.734665 [ 32690 ] {54af2512-e7ac-4397-a2d6-daa3f437612a} executeQuery: Code: 394. DB::Exception: Query '54af2512-e7ac-4397-a2d6-daa3f437612a' is killed in pending state. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38722) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:27.759485 [ 32690 ] {54af2512-e7ac-4397-a2d6-daa3f437612a} TCPHandler: Code: 394. DB::Exception: Query '54af2512-e7ac-4397-a2d6-daa3f437612a' is killed in pending state. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:27.808292 [ 32698 ] {840f3b52-311f-4c98-812d-1dcb8980ae49} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38710) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:27.810671 [ 32698 ] {840f3b52-311f-4c98-812d-1dcb8980ae49} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:27.900572 [ 3207 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:27.922335 [ 3532 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:28.039848 [ 3530 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:28.169392 [ 3549 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:28.221260 [ 32695 ] {757afdc5-de64-4303-8192-4811143652e0} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38796) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aedf669 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:52:28.230348 [ 32695 ] {757afdc5-de64-4303-8192-4811143652e0} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aedf669 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:52:28.234236 [ 32712 ] {23b39eb2-6234-48d1-b506-2e04a8116f00} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38788) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:28.251044 [ 32712 ] {23b39eb2-6234-48d1-b506-2e04a8116f00} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:28.300269 [ 32690 ] {4fc4e892-f128-4485-a0dd-35e8a546ecd9} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38772) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:28.302745 [ 32690 ] {4fc4e892-f128-4485-a0dd-35e8a546ecd9} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:28.316073 [ 4841 ] {66be03a0-af20-44e2-94ec-76bf367b6501} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38740) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:28.318059 [ 32698 ] {344258b9-8556-4333-aa9c-edc6c404b90c} executeQuery: Code: 394. DB::Exception: Query '344258b9-8556-4333-aa9c-edc6c404b90c' is killed in pending state. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38802) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:28.318475 [ 4841 ] {66be03a0-af20-44e2-94ec-76bf367b6501} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:28.343948 [ 32698 ] {344258b9-8556-4333-aa9c-edc6c404b90c} TCPHandler: Code: 394. DB::Exception: Query '344258b9-8556-4333-aa9c-edc6c404b90c' is killed in pending state. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:28.411985 [ 3510 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:28.469212 [ 32716 ] {e55e4e53-7705-4b99-9fb6-5acd47a02482} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38850) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:28.471635 [ 32716 ] {e55e4e53-7705-4b99-9fb6-5acd47a02482} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:28.480172 [ 32717 ] {a5bb4af5-c536-42ee-918d-78b4179aa78a} executeQuery: Code: 394. DB::Exception: Query 'a5bb4af5-c536-42ee-918d-78b4179aa78a' is killed in pending state. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38840) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:28.483010 [ 32717 ] {a5bb4af5-c536-42ee-918d-78b4179aa78a} TCPHandler: Code: 394. DB::Exception: Query 'a5bb4af5-c536-42ee-918d-78b4179aa78a' is killed in pending state. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:28.707001 [ 3497 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:28.775013 [ 32711 ] {75e5222d-0dfe-46a6-8578-181c7610733b} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38906) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:28.791622 [ 32711 ] {75e5222d-0dfe-46a6-8578-181c7610733b} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:28.901420 [ 3506 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:28.923009 [ 3063 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:29.040581 [ 3495 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:29.170338 [ 3481 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:29.274289 [ 32693 ] {3a62d6cd-6e15-4cd3-8130-83665a86eb1e} executeQuery: Code: 394. DB::Exception: Query '3a62d6cd-6e15-4cd3-8130-83665a86eb1e' is killed in pending state. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38940) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:29.289285 [ 3894 ] {fcc34bdb-fb04-4ba1-b345-e82bf7634c8e} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38964) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:29.299284 [ 3894 ] {fcc34bdb-fb04-4ba1-b345-e82bf7634c8e} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:29.299349 [ 32693 ] {3a62d6cd-6e15-4cd3-8130-83665a86eb1e} TCPHandler: Code: 394. DB::Exception: Query '3a62d6cd-6e15-4cd3-8130-83665a86eb1e' is killed in pending state. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:29.371754 [ 9453 ] {13729c49-fb39-489d-ad2f-0999ee5e6489} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38980) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:29.374137 [ 9453 ] {13729c49-fb39-489d-ad2f-0999ee5e6489} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:29.384099 [ 2903 ] {83121d41-9b4d-4d67-ab9f-f0c05e9eba33} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:39004) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:29.386494 [ 2903 ] {83121d41-9b4d-4d67-ab9f-f0c05e9eba33} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:29.404346 [ 32714 ] {443f78a0-a1e2-491e-a544-f6309bb60bf7} executeQuery: Code: 394. DB::Exception: Query '443f78a0-a1e2-491e-a544-f6309bb60bf7' is killed in pending state. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38954) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:29.412829 [ 3483 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:29.418175 [ 32714 ] {443f78a0-a1e2-491e-a544-f6309bb60bf7} TCPHandler: Code: 394. DB::Exception: Query '443f78a0-a1e2-491e-a544-f6309bb60bf7' is killed in pending state. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:29.442168 [ 32716 ] {d74a4cdb-98eb-4aca-9f3c-4d77f4f00662} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:39014) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:29.444585 [ 32716 ] {d74a4cdb-98eb-4aca-9f3c-4d77f4f00662} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:29.465982 [ 32712 ] {558d22bf-9cbb-4618-9306-b729182339e2} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=753). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:39036) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:52:29.473756 [ 32712 ] {558d22bf-9cbb-4618-9306-b729182339e2} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=753). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aee000c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:52:29.541087 [ 32709 ] {d1b42320-a492-427b-862e-8c5cc10746a7} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:39056) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aedf669 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:52:29.563946 [ 32709 ] {d1b42320-a492-427b-862e-8c5cc10746a7} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aedf669 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:52:29.757351 [ 3489 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:29.902188 [ 3487 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:29.923814 [ 3471 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:30.041263 [ 3455 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:30.171177 [ 3452 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:30.212361 [ 3894 ] {40e8e266-2ab7-418a-9984-8e73de1466e3} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:39136) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aedf669 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:52:30.235111 [ 3894 ] {40e8e266-2ab7-418a-9984-8e73de1466e3} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aedf669 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:52:30.301989 [ 2903 ] {39261828-bde4-4ad1-9188-0029aa44dd04} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:39144) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:30.304558 [ 2903 ] {39261828-bde4-4ad1-9188-0029aa44dd04} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:30.414063 [ 3466 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:30.453737 [ 32709 ] {a0f057c7-b1ae-4813-ab71-bc7fa4a236d1} executeQuery: Code: 394. DB::Exception: Query 'a0f057c7-b1ae-4813-ab71-bc7fa4a236d1' is killed in pending state. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:39164) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:30.456832 [ 32709 ] {a0f057c7-b1ae-4813-ab71-bc7fa4a236d1} TCPHandler: Code: 394. DB::Exception: Query 'a0f057c7-b1ae-4813-ab71-bc7fa4a236d1' is killed in pending state. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:30.590299 [ 32702 ] {8360b436-50cd-45b5-abbf-78081b2bf2ff} executeQuery: Code: 394. DB::Exception: Query '8360b436-50cd-45b5-abbf-78081b2bf2ff' is killed in pending state. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:39192) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:30.613388 [ 32702 ] {8360b436-50cd-45b5-abbf-78081b2bf2ff} TCPHandler: Code: 394. DB::Exception: Query '8360b436-50cd-45b5-abbf-78081b2bf2ff' is killed in pending state. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:30.758101 [ 3456 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:30.828539 [ 2903 ] {6ed68b9f-1d34-4873-8c3a-bd6485729948} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:39244) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:30.841670 [ 2903 ] {6ed68b9f-1d34-4873-8c3a-bd6485729948} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee6df8 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:30.903118 [ 3431 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:30.924516 [ 3454 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:31.041966 [ 3446 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:31.180295 [ 3434 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:31.260203 [ 4799 ] {06ce5d60-65b7-428f-8caa-eceb2f1ba4df} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:39326) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aedf669 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:52:31.262219 [ 4799 ] {06ce5d60-65b7-428f-8caa-eceb2f1ba4df} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:454: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x00000000350259de 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003aea2dc6 6. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x00000000322beb07 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003aedf669 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003aee168b 9. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb785 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:52:31.414979 [ 3425 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:31.645422 [ 32698 ] {9055c365-241a-43b0-ad64-810986bea93d} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:39394) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:31.649288 [ 32698 ] {9055c365-241a-43b0-ad64-810986bea93d} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:31.721473 [ 32701 ] {7ae7fad9-a77b-48b1-81f7-fcaf37578210} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:39410) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003aea508f 7. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee70d2 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:31.726203 [ 32701 ] {7ae7fad9-a77b-48b1-81f7-fcaf37578210} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003aea508f 7. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aee70d2 8. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aee79a4 9. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:431: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000035a492c6 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterKillQueryQuery::execute() @ 0x0000000035a33523 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 2025.10.23 23:52:31.758796 [ 3415 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:31.869323 [ 32714 ] {8dd1863c-89ba-45fd-a82a-1727140e7ea2} executeQuery: Code: 394. DB::Exception: Query '8dd1863c-89ba-45fd-a82a-1727140e7ea2' is killed in pending state. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:39480) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:31.880138 [ 32714 ] {8dd1863c-89ba-45fd-a82a-1727140e7ea2} TCPHandler: Code: 394. DB::Exception: Query '8dd1863c-89ba-45fd-a82a-1727140e7ea2' is killed in pending state. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e762a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1294: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358bed1d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 13. ? @ 0x00007f100c857ac3 14. ? @ 0x00007f100c8e9850 2025.10.23 23:52:31.904149 [ 3421 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:31.925488 [ 3414 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:31.960242 [ 32693 ] {21e697dc-4776-4c25-ba7b-f5e95019255d} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:39466) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:31.963273 [ 32693 ] {21e697dc-4776-4c25-ba7b-f5e95019255d} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:32.034224 [ 9453 ] {ed5a693e-5192-400f-b408-946d3bf18789} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:39494) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:32.036814 [ 9453 ] {ed5a693e-5192-400f-b408-946d3bf18789} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:32.040872 [ 32714 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:39480, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x00000000204bfd30 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x00000000204c0cc1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a8112cd 6. DB::ReadBuffer::next() @ 0x00000000095b468f 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000003abd729e 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:32.044181 [ 3393 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:32.053539 [ 32693 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:39466, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x00000000204bfd30 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x00000000204c0cc1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a8112cd 6. DB::ReadBuffer::next() @ 0x00000000095b468f 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000003abd729e 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:32.055112 [ 32701 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:39410, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x00000000204bfd30 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x00000000204c0cc1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a8112cd 6. DB::ReadBuffer::next() @ 0x00000000095b468f 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000003abd729e 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:32.060990 [ 9453 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:39494, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x00000000204bfd30 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x00000000204c0cc1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a8112cd 6. DB::ReadBuffer::next() @ 0x00000000095b468f 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000003abd729e 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:32.062776 [ 32132 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:39464, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x00000000204bfd30 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x00000000204c0cc1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a8112cd 6. DB::ReadBuffer::next() @ 0x00000000095b468f 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000003abd729e 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:32.094913 [ 32707 ] {bbf738cb-95c5-484d-b391-1ab8b0011a4f} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:39500) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:32.097440 [ 32707 ] {bbf738cb-95c5-484d-b391-1ab8b0011a4f} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x000000003502632d 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 10. ? @ 0x00007f100c857ac3 11. ? @ 0x00007f100c8e9850 2025.10.23 23:52:32.098220 [ 32707 ] {bbf738cb-95c5-484d-b391-1ab8b0011a4f} TCPHandler: Client has gone away. 2025.10.23 23:52:32.144440 [ 32717 ] {48ca0342-1e22-4e8d-b653-f4887b210820} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:39506, local: [::1]:9000). (NETWORK_ERROR) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:39506) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_15' SYNC 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x00000000204bfd30 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x00000000204c0cc1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a8112cd 6. DB::ReadBuffer::next() @ 0x00000000095b468f 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::getQueryCancellationStatus() @ 0x000000003ac0b9f9 8. ./build_docker/./src/Server/TCPHandler.cpp:1113: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb7e4 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:52:32.147158 [ 32717 ] {48ca0342-1e22-4e8d-b653-f4887b210820} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:39506). (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c6938 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a819e17 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000003ac2dd9a 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x000000003abff96a 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9aa8 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 14. ? @ 0x00007f100c857ac3 15. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:32.147602 [ 32717 ] {48ca0342-1e22-4e8d-b653-f4887b210820} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:39506, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 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&&) @ 0x00000000204c1edf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x00000000204bfd30 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x00000000204c0cc1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a8112cd 6. DB::ReadBuffer::next() @ 0x00000000095b468f 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::getQueryCancellationStatus() @ 0x000000003ac0b9f9 8. ./build_docker/./src/Server/TCPHandler.cpp:1113: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abfb7e4 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd9378 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 16. ? @ 0x00007f100c857ac3 17. ? @ 0x00007f100c8e9850 2025.10.23 23:52:32.148501 [ 32717 ] {48ca0342-1e22-4e8d-b653-f4887b210820} TCPHandler: Client has gone away. 2025.10.23 23:52:32.181374 [ 3404 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:32.416185 [ 3390 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:32.759588 [ 3413 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:32.905448 [ 3398 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:32.926424 [ 3377 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:33.045212 [ 3376 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:33.182503 [ 3360 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:33.417554 [ 3344 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:33.776579 [ 3315 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:33.906641 [ 3342 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:33.927324 [ 3372 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:34.046380 [ 3320 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:34.183516 [ 3332 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:34.418917 [ 3306 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:34.777732 [ 3313 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:34.907585 [ 3350 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:34.928255 [ 3301 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:35.047562 [ 3298 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:35.185707 [ 3325 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:35.420424 [ 3294 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:35.668384 [ 3317 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTablesParallel(std::vector, std::allocator>>) @ 0x00000000339c8298 8. ./contrib/llvm-project/libcxx/include/vector:438: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000339c92ee 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000339ec17f 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:35.779290 [ 3287 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:35.908764 [ 3292 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:35.928970 [ 3289 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:36.048835 [ 3283 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:36.187383 [ 3310 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:36.421765 [ 3276 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:36.780498 [ 3264 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:36.909918 [ 3255 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:36.929866 [ 3252 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:37.049631 [ 3251 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:37.188985 [ 3260 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:37.422979 [ 3244 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:37.781377 [ 3247 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:37.910877 [ 3235 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:37.930726 [ 3234 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:38.050608 [ 3218 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:38.190263 [ 3214 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:38.424483 [ 3208 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:38.782474 [ 3202 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:38.912323 [ 3189 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:38.931686 [ 3238 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:39.051933 [ 3185 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:39.191455 [ 3175 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:39.425964 [ 3156 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:39.784028 [ 3150 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:39.913525 [ 3152 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:39.932763 [ 3147 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:40.053142 [ 3145 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:40.192972 [ 3149 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:40.427303 [ 3126 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:40.653479 [ 32717 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b9e8a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159c809 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000003159ae8b 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000003159b78a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337543ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033755510 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003ac202e8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abf4918 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003abd7425 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.23 23:52:40.785100 [ 3138 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:40.914459 [ 3157 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:40.933730 [ 3114 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:41.054060 [ 3106 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:41.194063 [ 3101 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:41.428585 [ 3093 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:41.786157 [ 3088 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:41.915527 [ 3085 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:41.934493 [ 3084 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:42.056435 [ 3092 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:42.121387 [ 4674 ] {d1e1acc4-e075-4ee7-bcc9-642ea4658dca} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:33678) (comment: 01238_http_memory_tracking.sh) (in query: SELECT 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::writePrefix() @ 0x000000003b3c7288 9. ./src/Processors/Formats/IOutputFormat.h:0: DB::IOutputFormat::work() @ 0x000000003aeffd72 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:52:42.127195 [ 4674 ] {d1e1acc4-e075-4ee7-bcc9-642ea4658dca} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::writePrefix() @ 0x000000003b3c7288 9. ./src/Processors/Formats/IOutputFormat.h:0: DB::IOutputFormat::work() @ 0x000000003aeffd72 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:42.195591 [ 3059 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:42.429520 [ 3055 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:42.787222 [ 3391 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:42.916620 [ 3433 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:42.935212 [ 3223 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:43.057490 [ 3435 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:43.197319 [ 3322 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:43.430693 [ 3168 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:43.586207 [ 32716 ] {b2ffd763-fb3e-40aa-ad97-317b6197f997} executeQuery: Code: 232. DB::Exception: No part all_100_100_0 in committed state. (NO_SUCH_DATA_PART) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:40808) (comment: 01451_detach_drop_part.sql) (in query: ALTER TABLE mt_01451 DETACH PART 'all_100_100_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5088: DB::MergeTreeData::checkPartCanBeDropped(String const&, std::shared_ptr) @ 0x00000000397dc770 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x00000000397eeec9 6. ./src/QueryPipeline/Pipe.h:45: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034867310 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003485e550 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:52:43.587965 [ 32716 ] {b2ffd763-fb3e-40aa-ad97-317b6197f997} TCPHandler: Code: 232. DB::Exception: No part all_100_100_0 in committed state. (NO_SUCH_DATA_PART), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5088: DB::MergeTreeData::checkPartCanBeDropped(String const&, std::shared_ptr) @ 0x00000000397dc770 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x00000000397eeec9 6. ./src/QueryPipeline/Pipe.h:45: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034867310 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003485e550 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 2025.10.23 23:52:43.788337 [ 3542 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:43.917756 [ 3213 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:43.936234 [ 3544 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:44.058678 [ 3552 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:44.228315 [ 3529 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:44.432056 [ 3543 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:44.789432 [ 3207 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:44.918981 [ 3530 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:44.936996 [ 3526 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:45.060050 [ 3516 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:45.229356 [ 3523 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:45.433216 [ 3518 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:45.790686 [ 3520 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:45.920541 [ 3503 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:45.937813 [ 3501 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:46.061336 [ 3513 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:46.230673 [ 3502 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:46.434476 [ 3494 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:46.791923 [ 3481 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:46.922110 [ 3491 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:46.939029 [ 3512 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:47.062662 [ 3473 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:47.317214 [ 3480 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:47.436045 [ 3478 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:47.644316 [ 32707 ] {44119052-3ecd-4ed7-91af-a3cbbc3df9dc} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:51586) (comment: 01238_http_memory_tracking.sh) (in query: SELECT 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::writeSuffix() @ 0x000000003b3c762b 9. ./src/Processors/Formats/IOutputFormat.h:0: DB::IOutputFormat::work() @ 0x000000003af00072 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:52:47.650346 [ 32707 ] {44119052-3ecd-4ed7-91af-a3cbbc3df9dc} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::writeSuffix() @ 0x000000003b3c762b 9. ./src/Processors/Formats/IOutputFormat.h:0: DB::IOutputFormat::work() @ 0x000000003af00072 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:47.793491 [ 3464 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:47.832852 [ 32707 ] {8b003e68-b2ee-4c55-b3a1-ee44eb9c7c19} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:51622) (comment: 01238_http_memory_tracking.sh) (in query: SELECT 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::writePrefix() @ 0x000000003b3c7288 9. ./src/Processors/Formats/IOutputFormat.h:0: DB::IOutputFormat::work() @ 0x000000003aeffd72 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:52:47.851212 [ 32707 ] {8b003e68-b2ee-4c55-b3a1-ee44eb9c7c19} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::writePrefix() @ 0x000000003b3c7288 9. ./src/Processors/Formats/IOutputFormat.h:0: DB::IOutputFormat::work() @ 0x000000003aeffd72 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:47.923513 [ 3462 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:47.940255 [ 3453 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:47.979159 [ 32695 ] {9fd24983-4511-4786-8a9b-e52eeb9195b3} executeQuery: Code: 43. DB::Exception: Illegal types Decimal(9, 4) and Decimal(9, 4) of arguments for aggregate function covarPop. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:39518) (comment: 00700_decimal_aggregates.sql) (in query: SELECT covarPop(a, a), covarPop(b, b), covarPop(c, c) FROM decimal;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String const&) @ 0x000000002a6eac57 4. ./src/AggregateFunctions/AggregateFunctionStatisticsSimple.h:266: std::shared_ptr DB::createAggregateFunctionStatisticsBinary(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002d37630a 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002a2b4ea3 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306e2801 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 @ 0x00000000306dcf59 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334ae56e 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 30. ? @ 0x00007f100c857ac3 31. ? @ 0x00007f100c8e9850 2025.10.23 23:52:48.064131 [ 3450 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:48.074601 [ 32695 ] {9fd24983-4511-4786-8a9b-e52eeb9195b3} TCPHandler: Code: 43. DB::Exception: Illegal types Decimal(9, 4) and Decimal(9, 4) of arguments for aggregate function covarPop. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String const&) @ 0x000000002a6eac57 4. ./src/AggregateFunctions/AggregateFunctionStatisticsSimple.h:266: std::shared_ptr DB::createAggregateFunctionStatisticsBinary(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002d37630a 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002a2b4ea3 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306e2801 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 @ 0x00000000306dcf59 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334ae56e 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 30. ? @ 0x00007f100c857ac3 31. ? @ 0x00007f100c8e9850 2025.10.23 23:52:48.318607 [ 3445 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:48.350607 [ 32711 ] {ffadaf25-bd06-4060-a52d-e3aa1b3bd947} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:51654) (comment: 01238_http_memory_tracking.sh) (in query: SELECT 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::writeSuffix() @ 0x000000003b3c762b 9. ./src/Processors/Formats/IOutputFormat.h:0: DB::IOutputFormat::work() @ 0x000000003af00072 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:52:48.393427 [ 32711 ] {ffadaf25-bd06-4060-a52d-e3aa1b3bd947} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::writeSuffix() @ 0x000000003b3c762b 9. ./src/Processors/Formats/IOutputFormat.h:0: DB::IOutputFormat::work() @ 0x000000003af00072 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:48.437128 [ 3426 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:48.539145 [ 32716 ] {cacadf09-d4a8-4b6b-bc09-9b244e8323d0} executeQuery: Code: 233. DB::Exception: Detached part "all_4_4_0" not found. (BAD_DATA_PART_NAME) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:40808) (comment: 01451_detach_drop_part.sql) (in query: ALTER TABLE mt_01451 ATTACH PART 'all_4_4_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7484: DB::MergeTreeData::getDiskForDetachedPart(String const&) const @ 0x0000000039816321 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:6334: DB::MergeTreeData::tryLoadPartsToAttach(std::shared_ptr const&, bool, std::shared_ptr, DB::MergeTreeData::PartsTemporaryRename&) @ 0x0000000039818214 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::attachPartition(std::shared_ptr const&, std::shared_ptr const&, bool, std::shared_ptr) @ 0x000000003a35d504 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x00000000397eb9be 8. ./src/QueryPipeline/Pipe.h:45: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034867310 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003485e550 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:52:48.540933 [ 32716 ] {cacadf09-d4a8-4b6b-bc09-9b244e8323d0} TCPHandler: Code: 233. DB::Exception: Detached part "all_4_4_0" not found. (BAD_DATA_PART_NAME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7484: DB::MergeTreeData::getDiskForDetachedPart(String const&) const @ 0x0000000039816321 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:6334: DB::MergeTreeData::tryLoadPartsToAttach(std::shared_ptr const&, bool, std::shared_ptr, DB::MergeTreeData::PartsTemporaryRename&) @ 0x0000000039818214 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::attachPartition(std::shared_ptr const&, std::shared_ptr const&, bool, std::shared_ptr) @ 0x000000003a35d504 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x00000000397eb9be 8. ./src/QueryPipeline/Pipe.h:45: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034867310 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003485e550 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:52:48.794489 [ 3395 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:48.925073 [ 3390 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:48.941345 [ 3387 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:49.073097 [ 3413 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:49.319956 [ 3378 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:49.502844 [ 3402 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:49.795326 [ 3364 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:49.926468 [ 3379 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:49.942274 [ 3359 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:50.074321 [ 3339 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:50.321072 [ 3365 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:50.497708 [ 32707 ] {183ee275-3af6-4ccd-8177-26c570337ecf} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:51736) (comment: 01238_http_memory_tracking.sh) (in query: SELECT 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::writePrefix() @ 0x000000003b3c7288 9. ./src/Processors/Formats/IOutputFormat.h:0: DB::IOutputFormat::work() @ 0x000000003aeffd72 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:52:50.501344 [ 32707 ] {183ee275-3af6-4ccd-8177-26c570337ecf} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::writePrefix() @ 0x000000003b3c7288 9. ./src/Processors/Formats/IOutputFormat.h:0: DB::IOutputFormat::work() @ 0x000000003aeffd72 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:50.504076 [ 3328 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:50.680867 [ 32695 ] {6634d22d-7c6c-41e1-9b6a-4c0880238f95} executeQuery: Code: 43. DB::Exception: Illegal types Decimal(9, 4) and Decimal(9, 4) of arguments for aggregate function covarSamp. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:39518) (comment: 00700_decimal_aggregates.sql) (in query: SELECT covarSamp(a, a), covarSamp(b, b), covarSamp(c, c) FROM decimal;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String const&) @ 0x000000002a6eac57 4. ./src/AggregateFunctions/AggregateFunctionStatisticsSimple.h:266: std::shared_ptr DB::createAggregateFunctionStatisticsBinary(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002d3756aa 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002a2b4ea3 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306e2801 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 @ 0x00000000306dcf59 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334ae56e 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 30. ? @ 0x00007f100c857ac3 31. ? @ 0x00007f100c8e9850 2025.10.23 23:52:50.684181 [ 32695 ] {6634d22d-7c6c-41e1-9b6a-4c0880238f95} TCPHandler: Code: 43. DB::Exception: Illegal types Decimal(9, 4) and Decimal(9, 4) of arguments for aggregate function covarSamp. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String const&) @ 0x000000002a6eac57 4. ./src/AggregateFunctions/AggregateFunctionStatisticsSimple.h:266: std::shared_ptr DB::createAggregateFunctionStatisticsBinary(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002d3756aa 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002a2b4ea3 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306e2801 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 @ 0x00000000306dcf59 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334ae56e 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 30. ? @ 0x00007f100c857ac3 31. ? @ 0x00007f100c8e9850 2025.10.23 23:52:50.796539 [ 3342 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:50.928005 [ 3332 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:50.943287 [ 3318 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:51.075338 [ 3305 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:51.249706 [ 32707 ] {b5f59d25-df2e-41a7-b481-a4033371fa6c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:51836) (comment: 01238_http_memory_tracking.sh) (in query: SELECT 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::writePrefix() @ 0x000000003b3c7288 9. ./src/Processors/Formats/IOutputFormat.h:0: DB::IOutputFormat::work() @ 0x000000003aeffd72 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:52:51.253741 [ 32707 ] {b5f59d25-df2e-41a7-b481-a4033371fa6c} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::writePrefix() @ 0x000000003b3c7288 9. ./src/Processors/Formats/IOutputFormat.h:0: DB::IOutputFormat::work() @ 0x000000003aeffd72 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:51.322202 [ 3313 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:51.505586 [ 3335 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:51.797791 [ 3307 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:51.929091 [ 3340 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:51.944259 [ 3308 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:52.076432 [ 3317 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:52.323475 [ 3283 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:52.507168 [ 3284 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:52.798796 [ 3281 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:52.930069 [ 3261 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:52.944960 [ 3295 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:53.077365 [ 3274 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:53.204187 [ 32695 ] {9206b1ac-b139-41a1-ae48-5796688739a0} executeQuery: Code: 43. DB::Exception: Illegal types Decimal(9, 4) and Decimal(9, 4) of arguments for aggregate function corr. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:39518) (comment: 00700_decimal_aggregates.sql) (in query: SELECT corr(a, a), corr(b, b), corr(c, c) FROM decimal;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String const&) @ 0x000000002a6eac57 4. ./src/AggregateFunctions/AggregateFunctionStatisticsSimple.h:266: std::shared_ptr DB::createAggregateFunctionStatisticsBinary(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002d668b2f 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002a2b4ea3 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306e2801 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 @ 0x00000000306dcf59 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334ae56e 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 30. ? @ 0x00007f100c857ac3 31. ? @ 0x00007f100c8e9850 2025.10.23 23:52:53.205935 [ 32695 ] {9206b1ac-b139-41a1-ae48-5796688739a0} TCPHandler: Code: 43. DB::Exception: Illegal types Decimal(9, 4) and Decimal(9, 4) of arguments for aggregate function corr. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String const&) @ 0x000000002a6eac57 4. ./src/AggregateFunctions/AggregateFunctionStatisticsSimple.h:266: std::shared_ptr DB::createAggregateFunctionStatisticsBinary(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002d668b2f 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002a2b4ea3 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306e2801 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 @ 0x00000000306dcf59 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334ae56e 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344ed06 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003344bf91 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334e6100 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033436ae2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000334334e6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334319d9 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000034985339 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&) @ 0x0000000034cf4284 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034ceb8ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000034cf6cf5 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000034cf6853 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b948ec 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b5197 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000358a9d5d 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003abd9038 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003ac2e251 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 30. ? @ 0x00007f100c857ac3 31. ? @ 0x00007f100c8e9850 2025.10.23 23:52:53.324957 [ 3260 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:53.508533 [ 3269 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:53.799942 [ 3231 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:53.931257 [ 3239 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:53.945963 [ 3226 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:54.078529 [ 3232 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:54.089239 [ 32707 ] {bb4c56cc-23f1-4f6b-8815-ea3f4f0f8979} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:51954) (comment: 01238_http_memory_tracking.sh) (in query: SELECT 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Common/CollectionOfDerived.h:28: DB::ParallelFormattingOutputFormat::consume(DB::Chunk) @ 0x000000003b3c591d 9. ./src/Common/CollectionOfDerived.h:28: DB::IOutputFormat::work() @ 0x000000003af0033a 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:52:54.093613 [ 32707 ] {bb4c56cc-23f1-4f6b-8815-ea3f4f0f8979} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Common/CollectionOfDerived.h:28: DB::ParallelFormattingOutputFormat::consume(DB::Chunk) @ 0x000000003b3c591d 9. ./src/Common/CollectionOfDerived.h:28: DB::IOutputFormat::work() @ 0x000000003af0033a 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:54.326408 [ 3237 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:54.509525 [ 3216 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:54.801199 [ 3206 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:54.932875 [ 3212 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:54.947058 [ 3190 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:55.080114 [ 3208 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:55.328045 [ 3205 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:55.510625 [ 3238 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:55.802569 [ 3194 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:55.934263 [ 3188 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:55.948397 [ 3182 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:56.081213 [ 3180 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:56.180463 [ 32707 ] {bf9c84fe-f73a-4e47-a8e3-ef20dc0a26eb} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=750). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:51994) (comment: 01238_http_memory_tracking.sh) (in query: SELECT 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params)::'lambda'()&&) @ 0x000000003acb78b0 7. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params) @ 0x000000003acb66a4 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:76: DB::ParallelFormattingOutputFormat* std::construct_at[abi:v15007](DB::ParallelFormattingOutputFormat*, DB::ParallelFormattingOutputFormat::Params&) @ 0x000000003acb503d 9. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: DB::FormatFactory::getOutputFormatParallelIfPossible(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x000000003ac8ea0e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1590: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c74c1 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:52:56.245342 [ 32707 ] {bf9c84fe-f73a-4e47-a8e3-ef20dc0a26eb} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=750). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params)::'lambda'()&&) @ 0x000000003acb78b0 7. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params) @ 0x000000003acb66a4 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:76: DB::ParallelFormattingOutputFormat* std::construct_at[abi:v15007](DB::ParallelFormattingOutputFormat*, DB::ParallelFormattingOutputFormat::Params&) @ 0x000000003acb503d 9. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: DB::FormatFactory::getOutputFormatParallelIfPossible(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x000000003ac8ea0e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1590: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c74c1 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:56.329343 [ 3178 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:56.472872 [ 32707 ] {aaf77413-ad5e-4289-96c5-074804884387} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:57480) (comment: 01238_http_memory_tracking.sh) (in query: SELECT 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::writeSuffix() @ 0x000000003b3c762b 9. ./src/Processors/Formats/IOutputFormat.h:0: DB::IOutputFormat::work() @ 0x000000003af00072 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:52:56.476757 [ 32707 ] {aaf77413-ad5e-4289-96c5-074804884387} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::writeSuffix() @ 0x000000003b3c762b 9. ./src/Processors/Formats/IOutputFormat.h:0: DB::IOutputFormat::work() @ 0x000000003af00072 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:56.512054 [ 3151 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:56.803599 [ 3145 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:56.935619 [ 3134 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:56.949515 [ 3146 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:57.082109 [ 3177 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:57.330698 [ 3115 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:57.513361 [ 3129 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:57.804951 [ 3127 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:57.937082 [ 3112 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:57.950551 [ 3108 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:58.083128 [ 3113 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:58.332268 [ 3100 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:58.514660 [ 3096 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:58.806382 [ 3090 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:58.938274 [ 3070 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:58.951358 [ 3095 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:59.084440 [ 3077 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:59.333604 [ 3056 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:59.515893 [ 3073 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:59.807666 [ 3054 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:59.939388 [ 3443 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:59.952517 [ 3391 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:00.085496 [ 3223 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:00.334818 [ 3563 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:00.517092 [ 3197 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:00.793670 [ 4799 ] {34199876-f959-4390-a3e4-a96df93ccd77} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:57676) (comment: 01238_http_memory_tracking.sh) (in query: SELECT 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::finalizeImpl() @ 0x000000003b3bfa80 9. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:0: DB::IOutputFormat::work() @ 0x000000003af00097 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:53:00.808752 [ 3141 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:00.854037 [ 4799 ] {34199876-f959-4390-a3e4-a96df93ccd77} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::finalizeImpl() @ 0x000000003b3bfa80 9. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:0: DB::IOutputFormat::work() @ 0x000000003af00097 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:00.940978 [ 3201 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:00.953687 [ 3538 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:01.086774 [ 3551 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:01.336057 [ 3544 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:01.518294 [ 3552 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:01.809642 [ 3529 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:01.942586 [ 3528 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:01.955152 [ 3541 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:02.088654 [ 3548 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:02.337570 [ 3530 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:02.519584 [ 3546 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:02.810557 [ 3074 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:02.845077 [ 4799 ] {d775e103-0f00-4ffb-bb11-6e2aeecea738} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:57832) (comment: 01238_http_memory_tracking.sh) (in query: SELECT 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::finalizeImpl() @ 0x000000003b3bfa80 9. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:0: DB::IOutputFormat::work() @ 0x000000003af00097 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:53:02.849168 [ 4799 ] {d775e103-0f00-4ffb-bb11-6e2aeecea738} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::finalizeImpl() @ 0x000000003b3bfa80 9. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:0: DB::IOutputFormat::work() @ 0x000000003af00097 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:02.944018 [ 3515 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:02.956391 [ 3539 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:03.074072 [ 32711 ] {9365e5bf-f9b8-4659-8ccc-aa89e16986b6} 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.10542.altinitytest (altinity build)) (from [::1]:36094) (comment: 01396_inactive_replica_cleanup_nodes_zookeeper.sh) (in query: SELECT sum(toUInt32(extract(message, 'Removed (\d+) old log entries'))) FROM system.text_log WHERE event_date >= yesterday() AND logger_name LIKE '%' || 'test_uttb102q' || '%r1%(ReplicatedMergeTreeCleanupThread)%' AND message LIKE '%Removed % old log entries%'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 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) @ 0x0000000039c89948 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000003999bfb7 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 @ 0x00000000399942f0 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039d45fb0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003bfd663a 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c083c53 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003bfe2b53 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d3c440 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf89b85 18. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 19. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 23. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 24. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 26. ? @ 0x00007f100c857ac3 27. ? @ 0x00007f100c8e9850 2025.10.23 23:53:03.081012 [ 32711 ] {9365e5bf-f9b8-4659-8ccc-aa89e16986b6} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 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) @ 0x0000000039c89948 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000003999bfb7 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 @ 0x00000000399942f0 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039d45fb0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003bfd663a 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c083c53 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003bfe2b53 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d3c440 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf89b85 18. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 19. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 23. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 24. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 26. ? @ 0x00007f100c857ac3 27. ? @ 0x00007f100c8e9850 2025.10.23 23:53:03.089676 [ 3275 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:03.213525 [ 4799 ] {30530cae-d1a6-4aaf-aba1-82356089cd89} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=749). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:57868) (comment: 01238_http_memory_tracking.sh) (in query: SELECT 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params)::'lambda'()&&) @ 0x000000003acb78b0 7. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params) @ 0x000000003acb66a4 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:76: DB::ParallelFormattingOutputFormat* std::construct_at[abi:v15007](DB::ParallelFormattingOutputFormat*, DB::ParallelFormattingOutputFormat::Params&) @ 0x000000003acb503d 9. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: DB::FormatFactory::getOutputFormatParallelIfPossible(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x000000003ac8ea0e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1590: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c74c1 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:53:03.216418 [ 4799 ] {30530cae-d1a6-4aaf-aba1-82356089cd89} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=749). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params)::'lambda'()&&) @ 0x000000003acb78b0 7. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params) @ 0x000000003acb66a4 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:76: DB::ParallelFormattingOutputFormat* std::construct_at[abi:v15007](DB::ParallelFormattingOutputFormat*, DB::ParallelFormattingOutputFormat::Params&) @ 0x000000003acb503d 9. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: DB::FormatFactory::getOutputFormatParallelIfPossible(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x000000003ac8ea0e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1590: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c74c1 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:03.339070 [ 3500 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:03.520802 [ 3497 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:03.811668 [ 3063 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:03.945036 [ 3482 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:03.957391 [ 3494 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:04.090699 [ 3504 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:04.340345 [ 3469 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:04.521065 [ 32690 ] {5f8d6e4d-284a-4c48-92e1-09b5a8dd4876} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:58008) (comment: 01238_http_memory_tracking.sh) (in query: SELECT 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::writeSuffix() @ 0x000000003b3c762b 9. ./src/Processors/Formats/IOutputFormat.h:0: DB::IOutputFormat::work() @ 0x000000003af00072 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:53:04.521702 [ 3471 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:04.524858 [ 32690 ] {5f8d6e4d-284a-4c48-92e1-09b5a8dd4876} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::writeSuffix() @ 0x000000003b3c762b 9. ./src/Processors/Formats/IOutputFormat.h:0: DB::IOutputFormat::work() @ 0x000000003af00072 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:04.812779 [ 3448 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:04.889015 [ 4799 ] {dc0fbcdb-8a82-47da-a540-b4c127860d58} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:58026) (comment: 01238_http_memory_tracking.sh) (in query: SELECT 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Common/CollectionOfDerived.h:28: DB::ParallelFormattingOutputFormat::consume(DB::Chunk) @ 0x000000003b3c591d 9. ./src/Common/CollectionOfDerived.h:28: DB::IOutputFormat::work() @ 0x000000003af0033a 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:53:04.893109 [ 4799 ] {dc0fbcdb-8a82-47da-a540-b4c127860d58} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Common/CollectionOfDerived.h:28: DB::ParallelFormattingOutputFormat::consume(DB::Chunk) @ 0x000000003b3c591d 9. ./src/Common/CollectionOfDerived.h:28: DB::IOutputFormat::work() @ 0x000000003af0033a 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:04.946206 [ 3449 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:04.958236 [ 3450 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:05.091542 [ 3456 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:05.341354 [ 3431 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:05.522720 [ 3446 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:05.813580 [ 3430 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:05.947363 [ 3451 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:05.959109 [ 3419 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:06.092678 [ 3417 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:06.342563 [ 3421 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:06.523941 [ 3399 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:06.814572 [ 3392 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:06.949029 [ 3387 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:06.960200 [ 3401 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:07.093605 [ 3380 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:07.343987 [ 3378 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:07.525104 [ 3376 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:07.816156 [ 3375 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:07.950740 [ 3360 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:07.961641 [ 3371 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:08.094948 [ 3359 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:08.345421 [ 3346 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:08.526399 [ 3333 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:08.817194 [ 3338 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:08.952478 [ 3332 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:08.963194 [ 3318 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:09.096207 [ 3304 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:09.346781 [ 3297 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:09.547590 [ 3348 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:09.818274 [ 3309 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:09.953962 [ 3308 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:09.964594 [ 3300 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:10.097333 [ 3294 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:10.348122 [ 3299 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:10.549255 [ 3289 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:10.819534 [ 3280 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:10.955229 [ 3277 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:10.965603 [ 3281 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:11.098468 [ 3266 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:11.349409 [ 3274 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:11.550588 [ 3252 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:11.552647 [ 32690 ] {a775ea8b-170e-479b-b00f-c3b3249e7853} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38096) (comment: 02473_multistep_prewhere.sh) (in query: DROP DATABASE IF EXISTS test_kck3murb ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:53:11.557221 [ 32690 ] {a775ea8b-170e-479b-b00f-c3b3249e7853} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:11.600759 [ 2903 ] {716dc090-4be8-4167-9ffa-3df30bd07925} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38100) (comment: 02473_multistep_prewhere.sh) (in query: DROP DATABASE IF EXISTS test_kck3murb ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:53:11.605044 [ 2903 ] {716dc090-4be8-4167-9ffa-3df30bd07925} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:11.640218 [ 32690 ] {df343611-62cd-41e7-b14c-8e81c83c2216} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38112) (comment: 02473_multistep_prewhere.sh) (in query: DROP DATABASE IF EXISTS test_kck3murb ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:53:11.644728 [ 32690 ] {df343611-62cd-41e7-b14c-8e81c83c2216} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:11.732391 [ 2903 ] {60259701-08f7-445f-a379-dde8cad41731} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38114) (comment: 02473_multistep_prewhere.sh) (in query: DROP DATABASE IF EXISTS test_kck3murb ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:53:11.737107 [ 2903 ] {60259701-08f7-445f-a379-dde8cad41731} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:11.821091 [ 3256 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:11.956751 [ 3259 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:11.966564 [ 3244 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:12.099526 [ 3227 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:12.350851 [ 3230 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:12.552408 [ 3216 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:12.822087 [ 3211 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:12.957729 [ 3199 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:12.967331 [ 3198 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:13.100749 [ 3191 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:13.352542 [ 3188 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:13.553808 [ 3172 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:13.846404 [ 3183 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:13.958945 [ 3153 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:13.968405 [ 3160 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:14.102556 [ 3155 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:14.353927 [ 3163 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:14.555206 [ 3144 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:14.847590 [ 3137 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:14.960462 [ 3125 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:14.969553 [ 3118 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:15.189124 [ 3115 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:15.355312 [ 3136 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:15.556494 [ 3120 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:15.849135 [ 3107 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:15.962129 [ 3109 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:15.971004 [ 3117 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:16.190395 [ 3097 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:16.357039 [ 3100 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:16.369016 [ 3894 ] {6bebed45-c16d-4389-8ce5-874f1d4af629} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=749). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:43910) (comment: 01238_http_memory_tracking.sh) (in query: SELECT 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params)::'lambda'()&&) @ 0x000000003acb78b0 7. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params) @ 0x000000003acb66a4 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:76: DB::ParallelFormattingOutputFormat* std::construct_at[abi:v15007](DB::ParallelFormattingOutputFormat*, DB::ParallelFormattingOutputFormat::Params&) @ 0x000000003acb503d 9. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: DB::FormatFactory::getOutputFormatParallelIfPossible(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x000000003ac8ea0e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1590: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c74c1 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:53:16.456734 [ 3894 ] {6bebed45-c16d-4389-8ce5-874f1d4af629} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=749). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params)::'lambda'()&&) @ 0x000000003acb78b0 7. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params) @ 0x000000003acb66a4 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:76: DB::ParallelFormattingOutputFormat* std::construct_at[abi:v15007](DB::ParallelFormattingOutputFormat*, DB::ParallelFormattingOutputFormat::Params&) @ 0x000000003acb503d 9. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: DB::FormatFactory::getOutputFormatParallelIfPossible(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x000000003ac8ea0e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1590: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c74c1 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:16.557800 [ 3076 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:16.850495 [ 3090 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:16.963534 [ 3070 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:16.972251 [ 3079 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:17.191592 [ 3058 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:17.358344 [ 3069 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:17.559355 [ 3444 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:17.672426 [ 3894 ] {482ce1da-f049-43cf-bf96-e3326505ce2b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:44022) (comment: 01238_http_memory_tracking.sh) (in query: SELECT 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::finalizeImpl() @ 0x000000003b3bfa80 9. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:0: DB::IOutputFormat::work() @ 0x000000003af00097 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:53:17.677716 [ 3894 ] {482ce1da-f049-43cf-bf96-e3326505ce2b} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::finalizeImpl() @ 0x000000003b3bfa80 9. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:0: DB::IOutputFormat::work() @ 0x000000003af00097 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:17.852157 [ 3396 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:17.964942 [ 3057 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:17.973280 [ 3443 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:18.192644 [ 3319 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:18.359681 [ 3135 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:18.560761 [ 3551 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:18.853608 [ 3560 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:18.966339 [ 3559 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:18.974367 [ 3544 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:19.193390 [ 3529 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:19.361229 [ 3528 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:19.561781 [ 3543 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:19.780241 [ 4841 ] {0cfd1b67-b1e9-4229-8cfc-d4328af4f653} 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.10542.altinitytest (altinity build)) (from [::1]:54690) (comment: 01396_inactive_replica_cleanup_nodes_zookeeper.sh) (in query: SELECT sum(toUInt32(extract(message, 'Removed (\d+) old log entries'))) FROM system.text_log WHERE event_date >= yesterday() AND logger_name LIKE '%' || 'test_uttb102q' || '%r1%(ReplicatedMergeTreeCleanupThread)%' AND message LIKE '%Removed % old log entries%'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000039d07892 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&) @ 0x0000000039d09d4a 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:63: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x00000000326402a2 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000032640cad 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000039d01224 14. ./contrib/llvm-project/libcxx/include/vector:547: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000039d00b49 15. ./contrib/llvm-project/libcxx/include/__tree:1088: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) @ 0x00000000399bb1c8 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 @ 0x00000000399b0254 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039d46d05 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003bfd663a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c083c53 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003bfe2b53 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d3c440 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf89b85 23. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 24. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 28. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 31. ? @ 0x00007f100c857ac3 2025.10.23 23:53:19.787513 [ 4841 ] {0cfd1b67-b1e9-4229-8cfc-d4328af4f653} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000039d07892 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&) @ 0x0000000039d09d4a 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:63: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x00000000326402a2 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000032640cad 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000039d01224 14. ./contrib/llvm-project/libcxx/include/vector:547: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000039d00b49 15. ./contrib/llvm-project/libcxx/include/__tree:1088: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) @ 0x00000000399bb1c8 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 @ 0x00000000399b0254 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039d46d05 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003bfd663a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c083c53 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003bfe2b53 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d3c440 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf89b85 23. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 24. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 28. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 31. ? @ 0x00007f100c857ac3 2025.10.23 23:53:19.854650 [ 3526 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:19.967760 [ 3546 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:19.975355 [ 3519 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:20.194401 [ 3074 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:20.362498 [ 3515 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:20.562989 [ 3275 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:20.856106 [ 3508 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:20.969386 [ 3501 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:20.976627 [ 3500 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:21.195504 [ 3496 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:21.364030 [ 3063 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:21.445139 [ 3894 ] {436fbfc8-5624-4cf7-8dd3-026b4b5630a4} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:44376) (comment: 01238_http_memory_tracking.sh) (in query: SELECT 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::writeSuffix() @ 0x000000003b3c762b 9. ./src/Processors/Formats/IOutputFormat.h:0: DB::IOutputFormat::work() @ 0x000000003af00072 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:53:21.449561 [ 3894 ] {436fbfc8-5624-4cf7-8dd3-026b4b5630a4} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::writeSuffix() @ 0x000000003b3c762b 9. ./src/Processors/Formats/IOutputFormat.h:0: DB::IOutputFormat::work() @ 0x000000003af00072 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:21.540793 [ 3658 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {60ee07fc-67dc-4a3f-94ea-a31cb10c5a92::202510_1_221_44}: 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 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) @ 0x0000000039c89948 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000003999bfb7 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 @ 0x00000000399942f0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000039d15c04 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&) @ 0x0000000039d20399 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) @ 0x0000000039d1c606 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000396308a4 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x00000000396235dd 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000003963b3e0 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x00000000396504a0 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3c455d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:21.564347 [ 3512 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:21.693619 [ 3648 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {60ee07fc-67dc-4a3f-94ea-a31cb10c5a92::202510_1_221_44}: 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 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) @ 0x0000000039c89948 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000003999bfb7 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 @ 0x00000000399942f0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000039d15c04 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&) @ 0x0000000039d20399 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) @ 0x0000000039d1c606 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000396308a4 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x00000000396235dd 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000003963b3e0 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x00000000396504a0 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3c455d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:21.857079 [ 3469 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:21.970611 [ 3480 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:21.977898 [ 3487 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:22.197257 [ 3460 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:22.365186 [ 3459 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:22.565380 [ 3466 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:22.857890 [ 3454 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:22.971521 [ 3434 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:22.979275 [ 3440 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:23.198533 [ 3430 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:23.366173 [ 3445 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:23.566574 [ 3410 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:23.858750 [ 3416 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:23.972853 [ 3397 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:23.980414 [ 3403 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:24.199888 [ 3384 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:24.367474 [ 3387 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:24.568160 [ 3389 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:24.859909 [ 3374 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:24.973954 [ 3369 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:24.981495 [ 3368 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:25.200854 [ 3360 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:25.369573 [ 3370 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:25.426538 [ 32712 ] {ee09954f-daf3-4f89-9622-bd70f33159a0} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:49610) (comment: 01238_http_memory_tracking.sh) (in query: SELECT 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::writePrefix() @ 0x000000003b3c7288 9. ./src/Processors/Formats/IOutputFormat.h:0: DB::IOutputFormat::work() @ 0x000000003aeffd72 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:53:25.431400 [ 32712 ] {ee09954f-daf3-4f89-9622-bd70f33159a0} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::writePrefix() @ 0x000000003b3c7288 9. ./src/Processors/Formats/IOutputFormat.h:0: DB::IOutputFormat::work() @ 0x000000003aeffd72 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:25.569264 [ 3349 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:25.860995 [ 3347 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:25.933557 [ 3894 ] {8e330281-b330-40c5-80a9-68f4ce668a37} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:49670) (comment: 01238_http_memory_tracking.sh) (in query: SELECT 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::writeSuffix() @ 0x000000003b3c762b 9. ./src/Processors/Formats/IOutputFormat.h:0: DB::IOutputFormat::work() @ 0x000000003af00072 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:53:25.937589 [ 3894 ] {8e330281-b330-40c5-80a9-68f4ce668a37} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::writeSuffix() @ 0x000000003b3c762b 9. ./src/Processors/Formats/IOutputFormat.h:0: DB::IOutputFormat::work() @ 0x000000003af00072 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:25.975295 [ 3346 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:25.982997 [ 3357 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:26.201981 [ 3342 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:26.413252 [ 3320 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:26.570321 [ 3318 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:26.862252 [ 3304 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:26.976887 [ 3297 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:26.984499 [ 3313 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:27.073480 [ 32709 ] {d5ec806b-56d2-4192-85b4-ba4297951b19} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:49758) (comment: 01238_http_memory_tracking.sh) (in query: SELECT 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::writePrefix() @ 0x000000003b3c7288 9. ./src/Processors/Formats/IOutputFormat.h:0: DB::IOutputFormat::work() @ 0x000000003aeffd72 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:53:27.078003 [ 32709 ] {d5ec806b-56d2-4192-85b4-ba4297951b19} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::writePrefix() @ 0x000000003b3c7288 9. ./src/Processors/Formats/IOutputFormat.h:0: DB::IOutputFormat::work() @ 0x000000003aeffd72 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:27.202996 [ 3321 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:27.241001 [ 3894 ] {2660637f-3c48-4cd2-89a2-d13ecd031e83} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:49764) (comment: 01238_http_memory_tracking.sh) (in query: SELECT 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Common/CollectionOfDerived.h:28: DB::ParallelFormattingOutputFormat::consume(DB::Chunk) @ 0x000000003b3c591d 9. ./src/Common/CollectionOfDerived.h:28: DB::IOutputFormat::work() @ 0x000000003af0033a 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:53:27.246346 [ 3894 ] {2660637f-3c48-4cd2-89a2-d13ecd031e83} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Common/CollectionOfDerived.h:28: DB::ParallelFormattingOutputFormat::consume(DB::Chunk) @ 0x000000003b3c591d 9. ./src/Common/CollectionOfDerived.h:28: DB::IOutputFormat::work() @ 0x000000003af0033a 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:27.414595 [ 3309 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:27.571538 [ 3325 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:27.864485 [ 3302 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:27.977950 [ 3317 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:27.985454 [ 3299 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:28.204119 [ 3280 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:28.417951 [ 3264 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:28.628587 [ 3260 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:28.865931 [ 3243 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:28.979266 [ 3253 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:28.986575 [ 3249 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:29.205189 [ 3227 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:29.419489 [ 3239 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:29.630030 [ 3258 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:29.867278 [ 3221 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:29.980958 [ 3222 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:29.987651 [ 3225 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:30.206384 [ 3212 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:30.421517 [ 3209 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:30.631399 [ 3208 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:30.868197 [ 3219 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:30.982317 [ 3184 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:30.989006 [ 3238 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:31.066055 [ 32709 ] {c4f5b74b-51dd-4678-927d-49498680f40d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=749). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:50164) (comment: 01238_http_memory_tracking.sh) (in query: SELECT 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params)::'lambda'()&&) @ 0x000000003acb78b0 7. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params) @ 0x000000003acb66a4 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:76: DB::ParallelFormattingOutputFormat* std::construct_at[abi:v15007](DB::ParallelFormattingOutputFormat*, DB::ParallelFormattingOutputFormat::Params&) @ 0x000000003acb503d 9. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: DB::FormatFactory::getOutputFormatParallelIfPossible(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x000000003ac8ea0e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1590: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c74c1 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:53:31.068900 [ 32709 ] {c4f5b74b-51dd-4678-927d-49498680f40d} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=749). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params)::'lambda'()&&) @ 0x000000003acb78b0 7. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params) @ 0x000000003acb66a4 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:76: DB::ParallelFormattingOutputFormat* std::construct_at[abi:v15007](DB::ParallelFormattingOutputFormat*, DB::ParallelFormattingOutputFormat::Params&) @ 0x000000003acb503d 9. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: DB::FormatFactory::getOutputFormatParallelIfPossible(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x000000003ac8ea0e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1590: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c74c1 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:31.207476 [ 3192 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:31.422707 [ 3185 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:31.633084 [ 3170 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:31.869249 [ 3173 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:31.983425 [ 3167 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:31.989847 [ 3215 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:32.208674 [ 3160 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:32.424409 [ 3148 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:32.634365 [ 3150 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:32.843316 [ 32709 ] {132d8cd6-46aa-4ed2-ae3a-3b9f3d2afc49} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:50368) (comment: 01238_http_memory_tracking.sh) (in query: SELECT 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::writePrefix() @ 0x000000003b3c7288 9. ./src/Processors/Formats/IOutputFormat.h:0: DB::IOutputFormat::work() @ 0x000000003aeffd72 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:53:32.847343 [ 32709 ] {132d8cd6-46aa-4ed2-ae3a-3b9f3d2afc49} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::writePrefix() @ 0x000000003b3c7288 9. ./src/Processors/Formats/IOutputFormat.h:0: DB::IOutputFormat::work() @ 0x000000003aeffd72 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:32.870338 [ 3152 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:32.984844 [ 3147 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:32.990661 [ 3154 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:33.209843 [ 3149 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:33.425735 [ 3138 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:33.635445 [ 3119 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:33.871583 [ 3129 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:33.986345 [ 3116 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:33.991621 [ 3114 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:34.211209 [ 3159 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:34.426954 [ 3106 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:34.636658 [ 3117 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:34.873064 [ 3099 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:34.988221 [ 3093 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:34.992879 [ 3091 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:35.212506 [ 3082 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:35.428281 [ 3076 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:35.638020 [ 3078 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:35.874474 [ 3058 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:35.989542 [ 3059 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:35.994238 [ 3064 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:36.213903 [ 3069 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:36.429659 [ 3055 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:36.639443 [ 3296 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:36.804871 [ 32698 ] {95794460-319c-4008-bbe3-fa4b00139161} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:41314) (comment: 01238_http_memory_tracking.sh) (in query: SELECT 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::writePrefix() @ 0x000000003b3c7288 9. ./src/Processors/Formats/IOutputFormat.h:0: DB::IOutputFormat::work() @ 0x000000003aeffd72 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:53:36.812706 [ 32698 ] {95794460-319c-4008-bbe3-fa4b00139161} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::writePrefix() @ 0x000000003b3c7288 9. ./src/Processors/Formats/IOutputFormat.h:0: DB::IOutputFormat::work() @ 0x000000003aeffd72 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:36.867890 [ 32709 ] {5baad31a-6ccc-4e5c-b84b-132bee05d5e7} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:41330) (comment: 01238_http_memory_tracking.sh) (in query: SELECT 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::writePrefix() @ 0x000000003b3c7288 9. ./src/Processors/Formats/IOutputFormat.h:0: DB::IOutputFormat::work() @ 0x000000003aeffd72 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:53:36.872504 [ 32709 ] {5baad31a-6ccc-4e5c-b84b-132bee05d5e7} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::writePrefix() @ 0x000000003b3c7288 9. ./src/Processors/Formats/IOutputFormat.h:0: DB::IOutputFormat::work() @ 0x000000003aeffd72 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:36.875917 [ 3435 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:36.990742 [ 3197 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:36.995411 [ 3124 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:37.215168 [ 3168 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:37.430780 [ 3564 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:37.640821 [ 3362 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:37.877116 [ 3559 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:37.992160 [ 3552 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:37.996602 [ 3534 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:38.216318 [ 3555 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:38.514300 [ 3549 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:38.642092 [ 3074 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:38.878290 [ 3510 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:38.993440 [ 3499 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:38.997690 [ 3507 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:39.217392 [ 3500 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:39.516075 [ 3524 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:39.643394 [ 3502 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:39.879262 [ 3492 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:39.994916 [ 3484 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:39.998889 [ 3491 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:40.218678 [ 3490 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:40.399509 [ 4674 ] {7307aa47-657b-47f6-9cc0-ca1301b5954a} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=749). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:41648) (comment: 01238_http_memory_tracking.sh) (in query: SELECT 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params)::'lambda'()&&) @ 0x000000003acb78b0 7. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params) @ 0x000000003acb66a4 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:76: DB::ParallelFormattingOutputFormat* std::construct_at[abi:v15007](DB::ParallelFormattingOutputFormat*, DB::ParallelFormattingOutputFormat::Params&) @ 0x000000003acb503d 9. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: DB::FormatFactory::getOutputFormatParallelIfPossible(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x000000003ac8ea0e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1590: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c74c1 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:53:40.437421 [ 4674 ] {7307aa47-657b-47f6-9cc0-ca1301b5954a} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=749). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params)::'lambda'()&&) @ 0x000000003acb78b0 7. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params) @ 0x000000003acb66a4 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:76: DB::ParallelFormattingOutputFormat* std::construct_at[abi:v15007](DB::ParallelFormattingOutputFormat*, DB::ParallelFormattingOutputFormat::Params&) @ 0x000000003acb503d 9. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: DB::FormatFactory::getOutputFormatParallelIfPossible(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x000000003ac8ea0e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1590: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c74c1 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:40.517524 [ 3485 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:40.644796 [ 3487 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:40.880470 [ 3461 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:40.996261 [ 3463 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:41.000175 [ 3460 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:41.219974 [ 3467 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:41.245752 [ 4674 ] {b9d3c8b9-8c0f-4136-97bf-00b767fe9316} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:41702) (comment: 01238_http_memory_tracking.sh) (in query: SELECT 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Common/CollectionOfDerived.h:28: DB::ParallelFormattingOutputFormat::consume(DB::Chunk) @ 0x000000003b3c591d 9. ./src/Common/CollectionOfDerived.h:28: DB::IOutputFormat::work() @ 0x000000003af0033a 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:53:41.248939 [ 4674 ] {b9d3c8b9-8c0f-4136-97bf-00b767fe9316} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Common/CollectionOfDerived.h:28: DB::ParallelFormattingOutputFormat::consume(DB::Chunk) @ 0x000000003b3c591d 9. ./src/Common/CollectionOfDerived.h:28: DB::IOutputFormat::work() @ 0x000000003af0033a 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:41.278165 [ 4674 ] {8feda769-e558-48cc-9f13-477f193d3051} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:41716) (comment: 01238_http_memory_tracking.sh) (in query: SELECT 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::writePrefix() @ 0x000000003b3c7288 9. ./src/Processors/Formats/IOutputFormat.h:0: DB::IOutputFormat::work() @ 0x000000003aeffd72 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:53:41.281162 [ 4674 ] {8feda769-e558-48cc-9f13-477f193d3051} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::writePrefix() @ 0x000000003b3c7288 9. ./src/Processors/Formats/IOutputFormat.h:0: DB::IOutputFormat::work() @ 0x000000003aeffd72 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:41.324487 [ 32709 ] {cc863a87-803f-4a6b-afb3-16e24812bff7} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:41728) (comment: 01238_http_memory_tracking.sh) (in query: SELECT 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::writePrefix() @ 0x000000003b3c7288 9. ./src/Processors/Formats/IOutputFormat.h:0: DB::IOutputFormat::work() @ 0x000000003aeffd72 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:53:41.327686 [ 32709 ] {cc863a87-803f-4a6b-afb3-16e24812bff7} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::writePrefix() @ 0x000000003b3c7288 9. ./src/Processors/Formats/IOutputFormat.h:0: DB::IOutputFormat::work() @ 0x000000003aeffd72 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:41.519201 [ 3470 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:41.646309 [ 3441 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:41.881920 [ 3454 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:41.997619 [ 3423 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:42.001360 [ 3434 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:42.221133 [ 3425 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:42.520517 [ 3424 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:42.647538 [ 3417 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:42.883046 [ 3411 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:42.999018 [ 3421 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:43.003503 [ 3414 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:43.222188 [ 3395 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:43.521769 [ 3394 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:43.648526 [ 3439 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:43.884143 [ 3377 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:44.000197 [ 3378 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:44.004697 [ 3367 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:44.036811 [ 4674 ] {fbb457d7-ddd5-4acc-90c1-f9595e019943} executeQuery: Code: 241. DB::Exception: Memory tracker (for query): fault injected. Would use 1.00 MiB (attempt to allocate chunk of 1048639 bytes), maximum: 9.31 GiB: While executing ParallelFormattingOutputFormat. (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:41932) (comment: 01238_http_memory_tracking.sh) (in query: SELECT 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, String&&, long&, String&&) @ 0x000000002009baa7 4. ./build_docker/./src/Common/MemoryTracker.cpp:284: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002009a3d3 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099272 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7ca1d 7. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ff775a4 8. ./src/IO/BufferWithOwnMemory.h:0: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x000000003b3c251a 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003b3c7f63 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 2025.10.23 23:53:44.040681 [ 4674 ] {fbb457d7-ddd5-4acc-90c1-f9595e019943} DynamicQueryHandler: Code: 241. DB::Exception: Memory tracker (for query): fault injected. Would use 1.00 MiB (attempt to allocate chunk of 1048639 bytes), maximum: 9.31 GiB: While executing ParallelFormattingOutputFormat. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, String&&, long&, String&&) @ 0x000000002009baa7 4. ./build_docker/./src/Common/MemoryTracker.cpp:284: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002009a3d3 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099272 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7ca1d 7. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ff775a4 8. ./src/IO/BufferWithOwnMemory.h:0: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x000000003b3c251a 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003b3c7f63 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:44.223512 [ 3366 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:44.523280 [ 3359 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:44.649729 [ 3339 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:44.885103 [ 3334 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:44.903301 [ 32709 ] {124bddf6-c34d-4deb-ba69-d92b6d5cd766} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:42034) (comment: 01238_http_memory_tracking.sh) (in query: SELECT 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Common/CollectionOfDerived.h:28: DB::ParallelFormattingOutputFormat::consume(DB::Chunk) @ 0x000000003b3c591d 9. ./src/Common/CollectionOfDerived.h:28: DB::IOutputFormat::work() @ 0x000000003af0033a 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:53:44.909296 [ 32709 ] {124bddf6-c34d-4deb-ba69-d92b6d5cd766} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Common/CollectionOfDerived.h:28: DB::ParallelFormattingOutputFormat::consume(DB::Chunk) @ 0x000000003b3c591d 9. ./src/Common/CollectionOfDerived.h:28: DB::IOutputFormat::work() @ 0x000000003af0033a 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:45.001213 [ 3315 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:45.005527 [ 3373 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:45.224673 [ 3320 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:45.519292 [ 32695 ] {c48f4aa0-423f-488b-a209-f50b46444d27} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:55726) (comment: 01238_http_memory_tracking.sh) (in query: SELECT 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::writePrefix() @ 0x000000003b3c7288 9. ./src/Processors/Formats/IOutputFormat.h:0: DB::IOutputFormat::work() @ 0x000000003aeffd72 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:53:45.524002 [ 32695 ] {c48f4aa0-423f-488b-a209-f50b46444d27} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::writePrefix() @ 0x000000003b3c7288 9. ./src/Processors/Formats/IOutputFormat.h:0: DB::IOutputFormat::work() @ 0x000000003aeffd72 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:45.525028 [ 3332 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:45.609293 [ 32709 ] {fae5c474-6986-4c28-aa7c-bcf23368d92a} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=749). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:55746) (comment: 01238_http_memory_tracking.sh) (in query: SELECT 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params)::'lambda'()&&) @ 0x000000003acb78b0 7. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params) @ 0x000000003acb66a4 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:76: DB::ParallelFormattingOutputFormat* std::construct_at[abi:v15007](DB::ParallelFormattingOutputFormat*, DB::ParallelFormattingOutputFormat::Params&) @ 0x000000003acb503d 9. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: DB::FormatFactory::getOutputFormatParallelIfPossible(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x000000003ac8ea0e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1590: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c74c1 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:53:45.612295 [ 32709 ] {fae5c474-6986-4c28-aa7c-bcf23368d92a} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=749). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params)::'lambda'()&&) @ 0x000000003acb78b0 7. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params) @ 0x000000003acb66a4 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:76: DB::ParallelFormattingOutputFormat* std::construct_at[abi:v15007](DB::ParallelFormattingOutputFormat*, DB::ParallelFormattingOutputFormat::Params&) @ 0x000000003acb503d 9. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: DB::FormatFactory::getOutputFormatParallelIfPossible(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x000000003ac8ea0e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1590: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c74c1 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:45.651222 [ 3304 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:45.886240 [ 3297 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:45.933091 [ 32695 ] {3d620d23-271f-4e35-9230-62a449a43b46} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:55764) (comment: 01238_http_memory_tracking.sh) (in query: SELECT 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::writeSuffix() @ 0x000000003b3c762b 9. ./src/Processors/Formats/IOutputFormat.h:0: DB::IOutputFormat::work() @ 0x000000003af00072 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:53:45.938416 [ 32695 ] {3d620d23-271f-4e35-9230-62a449a43b46} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::writeSuffix() @ 0x000000003b3c762b 9. ./src/Processors/Formats/IOutputFormat.h:0: DB::IOutputFormat::work() @ 0x000000003af00072 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:46.002229 [ 3348 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:46.006753 [ 3298 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:46.225600 [ 3356 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:46.526579 [ 3290 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:46.652769 [ 3299 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:46.887681 [ 3292 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:47.004063 [ 3280 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:47.008352 [ 3284 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:47.226819 [ 3281 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:47.528100 [ 3266 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:47.654259 [ 3295 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:47.889024 [ 3271 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:48.005782 [ 3262 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:48.009549 [ 3267 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:48.228201 [ 3256 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:48.529170 [ 3226 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:48.655615 [ 3220 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:48.889869 [ 3245 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:49.006968 [ 3221 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:49.010832 [ 3222 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:49.229486 [ 3210 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:49.530032 [ 3199 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:49.657236 [ 3202 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:49.674277 [ 32709 ] {96d9354b-6abd-421a-bab6-d17e8d8abae1} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:56126) (comment: 01238_http_memory_tracking.sh) (in query: SELECT 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::writeSuffix() @ 0x000000003b3c762b 9. ./src/Processors/Formats/IOutputFormat.h:0: DB::IOutputFormat::work() @ 0x000000003af00072 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:53:49.677527 [ 32709 ] {96d9354b-6abd-421a-bab6-d17e8d8abae1} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::writeSuffix() @ 0x000000003b3c762b 9. ./src/Processors/Formats/IOutputFormat.h:0: DB::IOutputFormat::work() @ 0x000000003af00072 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:49.891031 [ 3184 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:50.008572 [ 3192 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:50.012278 [ 3181 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:50.230414 [ 3187 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:50.531071 [ 3180 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:50.566096 [ 32709 ] {6e6ae11b-4110-4eb7-95ae-fefe59d4e586} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:56194) (comment: 01238_http_memory_tracking.sh) (in query: SELECT 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::writePrefix() @ 0x000000003b3c7288 9. ./src/Processors/Formats/IOutputFormat.h:0: DB::IOutputFormat::work() @ 0x000000003aeffd72 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:53:50.570484 [ 32709 ] {6e6ae11b-4110-4eb7-95ae-fefe59d4e586} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::writePrefix() @ 0x000000003b3c7288 9. ./src/Processors/Formats/IOutputFormat.h:0: DB::IOutputFormat::work() @ 0x000000003aeffd72 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:50.658944 [ 3171 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:50.892392 [ 3215 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:51.009856 [ 3166 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:51.013510 [ 3156 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:51.231285 [ 3148 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:51.374872 [ 32709 ] {cef60f84-8766-4fe0-89f0-be69c3acccb3} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:56244) (comment: 01238_http_memory_tracking.sh) (in query: SELECT 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::writeSuffix() @ 0x000000003b3c762b 9. ./src/Processors/Formats/IOutputFormat.h:0: DB::IOutputFormat::work() @ 0x000000003af00072 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:53:51.380350 [ 32709 ] {cef60f84-8766-4fe0-89f0-be69c3acccb3} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::writeSuffix() @ 0x000000003b3c762b 9. ./src/Processors/Formats/IOutputFormat.h:0: DB::IOutputFormat::work() @ 0x000000003af00072 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:51.560605 [ 3133 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:51.660293 [ 3146 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:51.893544 [ 3126 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:52.011113 [ 3125 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:52.014816 [ 3118 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:52.232786 [ 3136 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:52.561746 [ 3127 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:52.661422 [ 3113 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:52.894621 [ 3117 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:53.012515 [ 3097 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:53.016338 [ 3102 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:53.233787 [ 3100 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:53.563231 [ 3078 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:53.662740 [ 3084 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:53.895831 [ 3092 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:54.014054 [ 3104 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:54.017515 [ 3069 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:54.234930 [ 3055 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:54.642468 [ 3396 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:54.664803 [ 3054 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:54.896985 [ 3391 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:55.015768 [ 3319 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:55.018680 [ 3418 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:55.236195 [ 3265 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:55.644197 [ 3197 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:55.666342 [ 3329 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:55.898091 [ 3168 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:56.017144 [ 3562 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:56.020168 [ 3098 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:56.237286 [ 3362 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:56.645781 [ 3552 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:56.667921 [ 3556 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:56.832727 [ 32709 ] {48ea6f30-f6c5-459c-a4ca-e4aaef3b2fa2} executeQuery: Code: 241. DB::Exception: Memory tracker (for query): fault injected. Would use 2.00 MiB (attempt to allocate chunk of 1048639 bytes), maximum: 9.31 GiB: While executing ParallelFormattingOutputFormat. (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:60674) (comment: 01238_http_memory_tracking.sh) (in query: SELECT 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, String&&, long&, String&&) @ 0x000000002009baa7 4. ./build_docker/./src/Common/MemoryTracker.cpp:284: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002009a3d3 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099272 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7ca1d 7. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ff775a4 8. ./src/IO/BufferWithOwnMemory.h:0: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x000000003b3c251a 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003b3c7f63 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 2025.10.23 23:53:56.838217 [ 32709 ] {48ea6f30-f6c5-459c-a4ca-e4aaef3b2fa2} DynamicQueryHandler: Code: 241. DB::Exception: Memory tracker (for query): fault injected. Would use 2.00 MiB (attempt to allocate chunk of 1048639 bytes), maximum: 9.31 GiB: While executing ParallelFormattingOutputFormat. (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, String&&, long&, String&&) @ 0x000000002009baa7 4. ./build_docker/./src/Common/MemoryTracker.cpp:284: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002009a3d3 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020099272 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7ca1d 7. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ff775a4 8. ./src/IO/BufferWithOwnMemory.h:0: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x000000003b3c251a 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003b3c7f63 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 15. ? @ 0x00007f100c857ac3 16. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:56.899273 [ 3527 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:57.018664 [ 3528 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:57.021370 [ 3541 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:57.238465 [ 3207 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:57.646991 [ 3546 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:57.669318 [ 3519 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:57.900525 [ 3547 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:58.020024 [ 3523 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:58.022370 [ 3514 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:58.239553 [ 3275 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:58.438932 [ 32717 ] {101d411e-0858-495f-885b-b74370d44828} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=750). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:60818) (comment: 01238_http_memory_tracking.sh) (in query: SELECT 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params)::'lambda'()&&) @ 0x000000003acb78b0 7. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params) @ 0x000000003acb66a4 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:76: DB::ParallelFormattingOutputFormat* std::construct_at[abi:v15007](DB::ParallelFormattingOutputFormat*, DB::ParallelFormattingOutputFormat::Params&) @ 0x000000003acb503d 9. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: DB::FormatFactory::getOutputFormatParallelIfPossible(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x000000003ac8ea0e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1590: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c74c1 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:53:58.441746 [ 32717 ] {101d411e-0858-495f-885b-b74370d44828} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=750). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params)::'lambda'()&&) @ 0x000000003acb78b0 7. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params) @ 0x000000003acb66a4 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:76: DB::ParallelFormattingOutputFormat* std::construct_at[abi:v15007](DB::ParallelFormattingOutputFormat*, DB::ParallelFormattingOutputFormat::Params&) @ 0x000000003acb503d 9. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: DB::FormatFactory::getOutputFormatParallelIfPossible(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x000000003ac8ea0e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1590: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c74c1 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:58.648553 [ 3502 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:58.649875 [ 32717 ] {4e332eec-4fa6-4dd2-8a8b-0a1186fdc462} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:60828) (comment: 01238_http_memory_tracking.sh) (in query: SELECT 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::writePrefix() @ 0x000000003b3c7288 9. ./src/Processors/Formats/IOutputFormat.h:0: DB::IOutputFormat::work() @ 0x000000003aeffd72 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:53:58.653243 [ 32717 ] {4e332eec-4fa6-4dd2-8a8b-0a1186fdc462} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::writePrefix() @ 0x000000003b3c7288 9. ./src/Processors/Formats/IOutputFormat.h:0: DB::IOutputFormat::work() @ 0x000000003aeffd72 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:58.670486 [ 3063 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:58.901862 [ 3481 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:59.021380 [ 3479 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:59.023408 [ 3490 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:59.240575 [ 3480 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:59.650230 [ 3463 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:59.671913 [ 3460 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:59.902964 [ 3459 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:00.022982 [ 3458 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:00.024501 [ 3464 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:00.241559 [ 3449 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:00.682162 [ 3441 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:00.682306 [ 3429 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:00.904031 [ 3434 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:00.950537 [ 32717 ] {4e26b783-cd1d-4d05-9a72-f0f55b8a21ad} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:32792) (comment: 01238_http_memory_tracking.sh) (in query: SELECT 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Common/CollectionOfDerived.h:28: DB::ParallelFormattingOutputFormat::consume(DB::Chunk) @ 0x000000003b3c591d 9. ./src/Common/CollectionOfDerived.h:28: DB::IOutputFormat::work() @ 0x000000003af0033a 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:54:00.955305 [ 32717 ] {4e26b783-cd1d-4d05-9a72-f0f55b8a21ad} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Common/CollectionOfDerived.h:28: DB::ParallelFormattingOutputFormat::consume(DB::Chunk) @ 0x000000003b3c591d 9. ./src/Common/CollectionOfDerived.h:28: DB::IOutputFormat::work() @ 0x000000003af0033a 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:00.993503 [ 32717 ] {391c265c-cc68-49fa-829c-20e3a7210c24} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=749). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:32794) (comment: 01238_http_memory_tracking.sh) (in query: SELECT 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params)::'lambda'()&&) @ 0x000000003acb78b0 7. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params) @ 0x000000003acb66a4 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:76: DB::ParallelFormattingOutputFormat* std::construct_at[abi:v15007](DB::ParallelFormattingOutputFormat*, DB::ParallelFormattingOutputFormat::Params&) @ 0x000000003acb503d 9. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: DB::FormatFactory::getOutputFormatParallelIfPossible(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x000000003ac8ea0e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1590: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c74c1 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:54:00.996584 [ 32717 ] {391c265c-cc68-49fa-829c-20e3a7210c24} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=749). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params)::'lambda'()&&) @ 0x000000003acb78b0 7. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params) @ 0x000000003acb66a4 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:76: DB::ParallelFormattingOutputFormat* std::construct_at[abi:v15007](DB::ParallelFormattingOutputFormat*, DB::ParallelFormattingOutputFormat::Params&) @ 0x000000003acb503d 9. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: DB::FormatFactory::getOutputFormatParallelIfPossible(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x000000003ac8ea0e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1590: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c74c1 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:01.025298 [ 3420 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:01.040947 [ 3419 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:01.168161 [ 32717 ] {13ee9b1d-913b-4894-8979-65e2b60961e2} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=749). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:32810) (comment: 01238_http_memory_tracking.sh) (in query: SELECT 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params)::'lambda'()&&) @ 0x000000003acb78b0 7. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params) @ 0x000000003acb66a4 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:76: DB::ParallelFormattingOutputFormat* std::construct_at[abi:v15007](DB::ParallelFormattingOutputFormat*, DB::ParallelFormattingOutputFormat::Params&) @ 0x000000003acb503d 9. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: DB::FormatFactory::getOutputFormatParallelIfPossible(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x000000003ac8ea0e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1590: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c74c1 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:54:01.171396 [ 32717 ] {13ee9b1d-913b-4894-8979-65e2b60961e2} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=749). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params)::'lambda'()&&) @ 0x000000003acb78b0 7. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params) @ 0x000000003acb66a4 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:76: DB::ParallelFormattingOutputFormat* std::construct_at[abi:v15007](DB::ParallelFormattingOutputFormat*, DB::ParallelFormattingOutputFormat::Params&) @ 0x000000003acb503d 9. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: DB::FormatFactory::getOutputFormatParallelIfPossible(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x000000003ac8ea0e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1590: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c74c1 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:01.242497 [ 3421 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:01.683151 [ 3397 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:01.683143 [ 3408 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:01.905466 [ 3387 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:02.026049 [ 3380 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:02.042906 [ 3388 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:02.243804 [ 3381 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:02.684497 [ 3382 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:02.750011 [ 3371 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:02.906757 [ 3336 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:03.027230 [ 3339 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:03.082338 [ 3354 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:03.245033 [ 3341 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:03.685866 [ 3324 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:03.751559 [ 3330 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:03.908084 [ 3303 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:04.028739 [ 3306 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:04.084000 [ 3353 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:04.246200 [ 3350 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:04.687226 [ 3311 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:04.753006 [ 3325 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:04.909191 [ 3308 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:05.029713 [ 3302 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:05.085069 [ 3290 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:05.247418 [ 3285 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:05.688564 [ 3286 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:05.754301 [ 3280 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:05.910292 [ 3310 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:06.030525 [ 3272 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:06.073680 [ 32711 ] {1eafb73f-75da-44a1-ab62-a30d43ad98b4} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:51626) (comment: 01238_http_memory_tracking.sh) (in query: SELECT 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::writeSuffix() @ 0x000000003b3c762b 9. ./src/Processors/Formats/IOutputFormat.h:0: DB::IOutputFormat::work() @ 0x000000003af00072 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:54:06.077314 [ 32711 ] {1eafb73f-75da-44a1-ab62-a30d43ad98b4} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::writeSuffix() @ 0x000000003b3c762b 9. ./src/Processors/Formats/IOutputFormat.h:0: DB::IOutputFormat::work() @ 0x000000003af00072 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:06.085911 [ 3276 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:06.248825 [ 3261 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:06.354092 [ 4799 ] {99935ffc-1239-4b11-90ef-86b9b1374c16} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:51640) (comment: 01238_http_memory_tracking.sh) (in query: SELECT 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Common/CollectionOfDerived.h:28: DB::ParallelFormattingOutputFormat::consume(DB::Chunk) @ 0x000000003b3c591d 9. ./src/Common/CollectionOfDerived.h:28: DB::IOutputFormat::work() @ 0x000000003af0033a 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:54:06.360829 [ 4799 ] {99935ffc-1239-4b11-90ef-86b9b1374c16} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Common/CollectionOfDerived.h:28: DB::ParallelFormattingOutputFormat::consume(DB::Chunk) @ 0x000000003b3c591d 9. ./src/Common/CollectionOfDerived.h:28: DB::IOutputFormat::work() @ 0x000000003af0033a 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:06.510666 [ 32711 ] {8415c564-c43d-420e-b952-9a5999bcb0c4} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:51648) (comment: 01238_http_memory_tracking.sh) (in query: SELECT 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Common/CollectionOfDerived.h:28: DB::ParallelFormattingOutputFormat::consume(DB::Chunk) @ 0x000000003b3c591d 9. ./src/Common/CollectionOfDerived.h:28: DB::IOutputFormat::work() @ 0x000000003af0033a 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:54:06.514667 [ 32711 ] {8415c564-c43d-420e-b952-9a5999bcb0c4} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Common/CollectionOfDerived.h:28: DB::ParallelFormattingOutputFormat::consume(DB::Chunk) @ 0x000000003b3c591d 9. ./src/Common/CollectionOfDerived.h:28: DB::IOutputFormat::work() @ 0x000000003af0033a 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:06.689778 [ 3252 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:06.755569 [ 3263 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:06.911540 [ 3250 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:07.031573 [ 3248 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:07.086947 [ 3243 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:07.249955 [ 3244 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:07.356906 [ 32711 ] {ef813099-7621-418d-bb3a-c6641bb41f59} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:51710) (comment: 01238_http_memory_tracking.sh) (in query: SELECT 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Common/CollectionOfDerived.h:28: DB::ParallelFormattingOutputFormat::consume(DB::Chunk) @ 0x000000003b3c591d 9. ./src/Common/CollectionOfDerived.h:28: DB::IOutputFormat::work() @ 0x000000003af0033a 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:54:07.360475 [ 32711 ] {ef813099-7621-418d-bb3a-c6641bb41f59} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Common/CollectionOfDerived.h:28: DB::ParallelFormattingOutputFormat::consume(DB::Chunk) @ 0x000000003b3c591d 9. ./src/Common/CollectionOfDerived.h:28: DB::IOutputFormat::work() @ 0x000000003af0033a 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:07.691167 [ 3231 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:07.757282 [ 3241 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:07.913285 [ 3228 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:08.032967 [ 3239 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:08.088562 [ 3232 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:08.251253 [ 3220 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:08.692470 [ 3184 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:08.758535 [ 3186 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:08.914661 [ 3188 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:09.033802 [ 3170 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:09.089832 [ 3180 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:09.257965 [ 3183 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:09.693374 [ 3161 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:09.759580 [ 3517 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:09.916063 [ 3145 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:09.978141 [ 32711 ] {c5c63e9d-b3f6-4449-8524-48e574293738} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:52022) (comment: 01238_http_memory_tracking.sh) (in query: SELECT 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Common/CollectionOfDerived.h:28: DB::ParallelFormattingOutputFormat::consume(DB::Chunk) @ 0x000000003b3c591d 9. ./src/Common/CollectionOfDerived.h:28: DB::IOutputFormat::work() @ 0x000000003af0033a 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:54:09.982908 [ 32711 ] {c5c63e9d-b3f6-4449-8524-48e574293738} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Common/CollectionOfDerived.h:28: DB::ParallelFormattingOutputFormat::consume(DB::Chunk) @ 0x000000003b3c591d 9. ./src/Common/CollectionOfDerived.h:28: DB::IOutputFormat::work() @ 0x000000003af0033a 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:10.035021 [ 3134 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:10.090845 [ 3177 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:10.258758 [ 3118 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:10.694783 [ 3164 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:10.760846 [ 3123 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:10.916948 [ 3120 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:11.036485 [ 3108 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:11.092045 [ 3113 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:11.259798 [ 3107 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:11.696422 [ 3102 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:11.762197 [ 3110 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:11.918096 [ 3100 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:12.037870 [ 3089 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:12.093332 [ 3096 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:12.261139 [ 3075 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:12.697749 [ 3072 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:12.763920 [ 3058 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:12.919210 [ 3081 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:13.038911 [ 3104 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:13.094714 [ 3056 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:13.262095 [ 3060 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:13.698956 [ 3345 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:13.765149 [ 3433 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:13.920582 [ 3291 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:14.040055 [ 3563 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:14.096416 [ 3124 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:14.263059 [ 3141 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:14.360661 [ 32690 ] {5d2a141e-cdf4-493e-a161-600125be6eca} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=750). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:52456) (comment: 01238_http_memory_tracking.sh) (in query: SELECT 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params)::'lambda'()&&) @ 0x000000003acb78b0 7. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params) @ 0x000000003acb66a4 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:76: DB::ParallelFormattingOutputFormat* std::construct_at[abi:v15007](DB::ParallelFormattingOutputFormat*, DB::ParallelFormattingOutputFormat::Params&) @ 0x000000003acb503d 9. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: DB::FormatFactory::getOutputFormatParallelIfPossible(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x000000003ac8ea0e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1590: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c74c1 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:54:14.364767 [ 32690 ] {5d2a141e-cdf4-493e-a161-600125be6eca} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=750). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params)::'lambda'()&&) @ 0x000000003acb78b0 7. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params) @ 0x000000003acb66a4 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:76: DB::ParallelFormattingOutputFormat* std::construct_at[abi:v15007](DB::ParallelFormattingOutputFormat*, DB::ParallelFormattingOutputFormat::Params&) @ 0x000000003acb503d 9. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: DB::FormatFactory::getOutputFormatParallelIfPossible(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x000000003ac8ea0e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1590: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c74c1 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:14.700383 [ 3542 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:14.717016 [ 32690 ] {0be465f5-4dc7-4742-bf1f-b548afec1376} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=750). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:52480) (comment: 01238_http_memory_tracking.sh) (in query: SELECT 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params)::'lambda'()&&) @ 0x000000003acb78b0 7. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params) @ 0x000000003acb66a4 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:76: DB::ParallelFormattingOutputFormat* std::construct_at[abi:v15007](DB::ParallelFormattingOutputFormat*, DB::ParallelFormattingOutputFormat::Params&) @ 0x000000003acb503d 9. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: DB::FormatFactory::getOutputFormatParallelIfPossible(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x000000003ac8ea0e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1590: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c74c1 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:54:14.721692 [ 32690 ] {0be465f5-4dc7-4742-bf1f-b548afec1376} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=750). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params)::'lambda'()&&) @ 0x000000003acb78b0 7. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params) @ 0x000000003acb66a4 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:76: DB::ParallelFormattingOutputFormat* std::construct_at[abi:v15007](DB::ParallelFormattingOutputFormat*, DB::ParallelFormattingOutputFormat::Params&) @ 0x000000003acb503d 9. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: DB::FormatFactory::getOutputFormatParallelIfPossible(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x000000003ac8ea0e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1590: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c74c1 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:14.766596 [ 3111 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:14.921794 [ 3561 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:15.041398 [ 3536 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:15.097695 [ 3213 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:15.119107 [ 32690 ] {356504ec-9106-4da0-9737-596e12bd0f66} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:45044) (comment: 01238_http_memory_tracking.sh) (in query: SELECT 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::writeSuffix() @ 0x000000003b3c762b 9. ./src/Processors/Formats/IOutputFormat.h:0: DB::IOutputFormat::work() @ 0x000000003af00072 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:54:15.124566 [ 32690 ] {356504ec-9106-4da0-9737-596e12bd0f66} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::writeSuffix() @ 0x000000003b3c762b 9. ./src/Processors/Formats/IOutputFormat.h:0: DB::IOutputFormat::work() @ 0x000000003af00072 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:15.264299 [ 3540 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:15.701934 [ 3535 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:15.768128 [ 3555 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:15.923050 [ 3543 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:16.042929 [ 3565 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:16.098859 [ 3548 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:16.265480 [ 3236 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:16.703229 [ 3516 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:16.769153 [ 3074 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:16.918248 [ 32690 ] {b37aacdd-00ff-4669-bcee-dc0f3a7dc743} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:45230) (comment: 01238_http_memory_tracking.sh) (in query: SELECT 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::finalizeImpl() @ 0x000000003b3bfa80 9. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:0: DB::IOutputFormat::work() @ 0x000000003af00097 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:54:16.922066 [ 32690 ] {b37aacdd-00ff-4669-bcee-dc0f3a7dc743} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::finalizeImpl() @ 0x000000003b3bfa80 9. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:0: DB::IOutputFormat::work() @ 0x000000003af00097 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:16.924560 [ 3515 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:16.971457 [ 32711 ] {a1297321-660a-482a-a9a5-c49df7aa8634} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, jobs=2): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:54520) (comment: 01396_inactive_replica_cleanup_nodes_zookeeper.sh) (in query: SELECT sum(toUInt32(extract(message, 'Removed (\d+) old log entries'))) FROM system.text_log WHERE event_date >= yesterday() AND logger_name LIKE '%' || 'test_uttb102q' || '%r1%(ReplicatedMergeTreeCleanupThread)%' AND message LIKE '%Removed % old log entries%'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000039d07892 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&) @ 0x0000000039d09d4a 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:63: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x00000000326402a2 12. ./build_docker/./src/DataTypes/Serializations/SerializationLowCardinality.cpp:59: DB::SerializationLowCardinality::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000003274547e 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000032640cad 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000039d01224 15. ./contrib/llvm-project/libcxx/include/vector:547: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000039d00b49 16. ./contrib/llvm-project/libcxx/include/__tree:1088: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) @ 0x00000000399bb1c8 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 @ 0x00000000399b0254 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039d46d05 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003bfd663a 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c083c53 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003bfe2b53 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d3c440 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf89b85 24. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 25. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 29. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 2025.10.23 23:54:16.977873 [ 32711 ] {a1297321-660a-482a-a9a5-c49df7aa8634} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, jobs=2): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000039d07892 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&) @ 0x0000000039d09d4a 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:63: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x00000000326402a2 12. ./build_docker/./src/DataTypes/Serializations/SerializationLowCardinality.cpp:59: DB::SerializationLowCardinality::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000003274547e 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000032640cad 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000039d01224 15. ./contrib/llvm-project/libcxx/include/vector:547: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000039d00b49 16. ./contrib/llvm-project/libcxx/include/__tree:1088: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) @ 0x00000000399bb1c8 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 @ 0x00000000399b0254 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039d46d05 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003bfd663a 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c083c53 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003bfe2b53 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d3c440 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf89b85 24. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 25. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 29. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 2025.10.23 23:54:17.044051 [ 3518 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:17.100291 [ 3522 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:17.266697 [ 3498 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:17.704424 [ 3502 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:17.770345 [ 3495 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:17.925799 [ 3493 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:17.980122 [ 32711 ] {c97a7937-a8af-4e79-b74f-0b42fa4aa7ec} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:45298) (comment: 01238_http_memory_tracking.sh) (in query: SELECT 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::writeSuffix() @ 0x000000003b3c762b 9. ./src/Processors/Formats/IOutputFormat.h:0: DB::IOutputFormat::work() @ 0x000000003af00072 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:54:17.985489 [ 32711 ] {c97a7937-a8af-4e79-b74f-0b42fa4aa7ec} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::writeSuffix() @ 0x000000003b3c762b 9. ./src/Processors/Formats/IOutputFormat.h:0: DB::IOutputFormat::work() @ 0x000000003af00072 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:18.045056 [ 3504 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:18.101596 [ 3483 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:18.267639 [ 3480 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:18.706121 [ 3465 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:18.771829 [ 3464 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:18.926972 [ 3437 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:19.046368 [ 3429 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:19.102742 [ 3423 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:19.269034 [ 3426 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:19.707491 [ 3436 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:19.773635 [ 3424 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:19.928560 [ 3415 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:20.047672 [ 3414 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:20.103983 [ 3407 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:20.270532 [ 3405 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:20.487308 [ 32711 ] {ed8a550a-2c02-427d-98ba-72668c712336} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:45530) (comment: 01238_http_memory_tracking.sh) (in query: SELECT 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::writePrefix() @ 0x000000003b3c7288 9. ./src/Processors/Formats/IOutputFormat.h:0: DB::IOutputFormat::work() @ 0x000000003aeffd72 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:54:20.494589 [ 32711 ] {ed8a550a-2c02-427d-98ba-72668c712336} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::writePrefix() @ 0x000000003b3c7288 9. ./src/Processors/Formats/IOutputFormat.h:0: DB::IOutputFormat::work() @ 0x000000003aeffd72 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:20.708934 [ 3390 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:20.775017 [ 3401 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:20.929851 [ 3413 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:21.048803 [ 3380 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:21.105300 [ 3378 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:21.306547 [ 3367 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:21.710107 [ 3366 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:21.776694 [ 3385 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:21.931155 [ 3382 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:22.049782 [ 3336 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:22.106311 [ 3352 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:22.307850 [ 3326 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:22.711424 [ 3315 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:22.777929 [ 3372 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:22.932277 [ 3338 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:23.050812 [ 3323 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:23.107379 [ 3304 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:23.253279 [ 32711 ] {3936cbea-eb2c-4c96-ad27-9984628c24a9} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:45788) (comment: 01238_http_memory_tracking.sh) (in query: SELECT 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::writeSuffix() @ 0x000000003b3c762b 9. ./src/Processors/Formats/IOutputFormat.h:0: DB::IOutputFormat::work() @ 0x000000003af00072 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 2025.10.23 23:54:23.258756 [ 32711 ] {3936cbea-eb2c-4c96-ad27-9984628c24a9} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003b3c4577 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:0: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b3c1185 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::writeSuffix() @ 0x000000003b3c762b 9. ./src/Processors/Formats/IOutputFormat.h:0: DB::IOutputFormat::work() @ 0x000000003af00072 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003aea065f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c8ad3 16. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 17. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 24. ? @ 0x00007f100c857ac3 25. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:23.309166 [ 3355 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:23.713079 [ 3331 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:23.779104 [ 3311 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:23.933448 [ 3308 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:24.052350 [ 3302 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:24.109081 [ 3290 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:24.310289 [ 3299 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:24.769873 [ 3284 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:24.780337 [ 3278 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:24.934754 [ 3281 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:25.053602 [ 3272 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:25.110403 [ 3266 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:25.311248 [ 3268 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:25.403988 [ 32711 ] {eccfca1f-081d-4277-b544-6b0f2c750d0a} 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.10542.altinitytest (altinity build)) (from [::1]:48656) (comment: 01396_inactive_replica_cleanup_nodes_zookeeper.sh) (in query: SELECT sum(toUInt32(extract(message, 'Removed (\d+) old log entries'))) FROM system.text_log WHERE event_date >= yesterday() AND logger_name LIKE '%' || 'test_uttb102q' || '%r1%(ReplicatedMergeTreeCleanupThread)%' AND message LIKE '%Removed % old log entries%'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000039d07892 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&) @ 0x0000000039d09d4a 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:63: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x00000000326402a2 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000032640cad 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000039d01224 14. ./contrib/llvm-project/libcxx/include/vector:547: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000039d00b49 15. ./contrib/llvm-project/libcxx/include/__tree:1088: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) @ 0x00000000399bb1c8 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 @ 0x00000000399b0254 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039d46d05 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003bfd663a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c083c53 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003bfe2b53 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d3c440 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf89b85 23. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 24. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 28. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 31. ? @ 0x00007f100c857ac3 2025.10.23 23:54:25.410577 [ 32711 ] {eccfca1f-081d-4277-b544-6b0f2c750d0a} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000039d07892 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&) @ 0x0000000039d09d4a 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:63: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x00000000326402a2 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000032640cad 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000039d01224 14. ./contrib/llvm-project/libcxx/include/vector:547: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000039d00b49 15. ./contrib/llvm-project/libcxx/include/__tree:1088: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) @ 0x00000000399bb1c8 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 @ 0x00000000399b0254 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039d46d05 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003bfd663a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c083c53 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003bfe2b53 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d3c440 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf89b85 23. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 24. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 28. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 31. ? @ 0x00007f100c857ac3 2025.10.23 23:54:25.770921 [ 3263 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:25.781256 [ 3271 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:25.935944 [ 3250 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:26.054524 [ 3260 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:26.111522 [ 3248 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:26.401575 [ 3233 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:26.772061 [ 3226 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:26.782077 [ 3232 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:26.786453 [ 3645 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {959c1387-6a29-41af-9a70-593d11e44aac::202510_1_157_31}: 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 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) @ 0x0000000039c89948 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000003999bfb7 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 @ 0x00000000399942f0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000039d15c04 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&) @ 0x0000000039d20399 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) @ 0x0000000039d1c606 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000396308a4 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x00000000396235dd 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000003963b3e0 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x00000000396504a0 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3c455d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:26.936853 [ 3224 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:27.055315 [ 3218 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:27.112667 [ 3221 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:27.402759 [ 3202 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:27.773041 [ 3186 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:27.783150 [ 3185 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:27.937751 [ 3188 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:28.056517 [ 3182 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:28.114003 [ 3172 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:28.404215 [ 3153 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:28.484997 [ 3654 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {d60c8165-1f8c-4cd1-8084-8b8c63363ea3::202510_99_186_51}: 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000002009b98d 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x000000002009675f 5. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:129: CurrentMemoryTracker::injectFault() @ 0x000000001ff7d1df 6. ./build_docker/./src/Common/ThreadFuzzer.cpp:270: DB::ThreadFuzzer::maybeInjectMemoryLimitException() @ 0x000000002011909f 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:151: DB::MergePlainMergeTreeTask::finish() @ 0x000000003a3c7732 8. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3c4534 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:28.774087 [ 3154 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:28.784405 [ 3145 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:28.921307 [ 3894 ] {820013e4-61db-44d1-b949-daadc8e658d1} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=749). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:56948) (comment: 01238_http_memory_tracking.sh) (in query: SELECT 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params)::'lambda'()&&) @ 0x000000003acb78b0 7. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params) @ 0x000000003acb66a4 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:76: DB::ParallelFormattingOutputFormat* std::construct_at[abi:v15007](DB::ParallelFormattingOutputFormat*, DB::ParallelFormattingOutputFormat::Params&) @ 0x000000003acb503d 9. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: DB::FormatFactory::getOutputFormatParallelIfPossible(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x000000003ac8ea0e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1590: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c74c1 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:54:28.938555 [ 3137 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:28.950680 [ 3894 ] {820013e4-61db-44d1-b949-daadc8e658d1} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=800, jobs=749). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e41b4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d2689 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4334 6. ./src/Common/ThreadPool.h:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params)::'lambda'()&&) @ 0x000000003acb78b0 7. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:0: DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params) @ 0x000000003acb66a4 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:76: DB::ParallelFormattingOutputFormat* std::construct_at[abi:v15007](DB::ParallelFormattingOutputFormat*, DB::ParallelFormattingOutputFormat::Params&) @ 0x000000003acb503d 9. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: DB::FormatFactory::getOutputFormatParallelIfPossible(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x000000003ac8ea0e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1590: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c74c1 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:29.057429 [ 3162 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:29.115080 [ 3125 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:29.405071 [ 3140 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:29.775230 [ 3130 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:29.785465 [ 3108 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:29.939740 [ 3107 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:30.058328 [ 3117 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:30.116145 [ 3101 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:30.406264 [ 3100 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:30.776583 [ 3075 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:30.786634 [ 3085 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:30.940888 [ 3105 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:31.059501 [ 3078 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:31.117946 [ 3079 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:31.407339 [ 3081 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:31.777749 [ 3060 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:31.788506 [ 3444 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:31.942320 [ 3073 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:32.083630 [ 3396 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:32.119486 [ 3054 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:32.408686 [ 3418 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:32.778765 [ 3203 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:32.789958 [ 3435 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:32.944127 [ 3563 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:33.084884 [ 3406 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:33.120848 [ 3141 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:33.410001 [ 3111 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:33.780046 [ 3213 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:33.791118 [ 3559 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:33.945404 [ 3552 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:34.085934 [ 3557 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:34.121966 [ 3553 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:34.411280 [ 3543 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:34.781393 [ 3516 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:34.792323 [ 3547 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:34.946331 [ 3515 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:35.087235 [ 3511 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:35.123219 [ 3539 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:35.412951 [ 3520 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:35.782986 [ 3509 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:35.787135 [ 3647 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {26a86919-b755-436d-800b-c04857d425d1::202510_1_220_98}: 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000002009b98d 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x000000002009675f 5. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:129: CurrentMemoryTracker::injectFault() @ 0x000000001ff7d1df 6. ./build_docker/./src/Common/ThreadFuzzer.cpp:270: DB::ThreadFuzzer::maybeInjectMemoryLimitException() @ 0x000000002011909f 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:151: DB::MergePlainMergeTreeTask::finish() @ 0x000000003a3c7732 8. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3c4534 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:35.793477 [ 3524 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:35.947207 [ 3506 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:36.088208 [ 3488 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:36.124710 [ 3482 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:36.414308 [ 3504 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:36.784402 [ 3473 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:36.794763 [ 3475 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:36.948705 [ 3472 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:37.089154 [ 3478 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:37.126306 [ 3460 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:37.415544 [ 3459 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:37.785654 [ 3453 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:37.796537 [ 3466 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:37.950064 [ 3470 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:38.090296 [ 3450 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:38.127630 [ 3431 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:38.416810 [ 3424 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:38.786641 [ 3421 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:38.798524 [ 3414 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:38.951198 [ 3412 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:39.091454 [ 3395 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:39.129189 [ 3404 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:39.417858 [ 3390 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:39.788041 [ 3380 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:39.800011 [ 3388 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:39.952615 [ 3377 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:40.093014 [ 3367 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:40.131002 [ 3383 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:40.418979 [ 3385 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:40.789169 [ 3364 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:40.801761 [ 3359 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:40.953844 [ 3349 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:41.094230 [ 3339 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:41.132374 [ 3354 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:41.420111 [ 3347 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:41.790162 [ 3342 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:41.802934 [ 3316 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:41.954861 [ 3338 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:42.095530 [ 3323 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:42.133579 [ 3304 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:42.421077 [ 3301 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:42.791505 [ 3325 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:42.804314 [ 3340 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:42.956100 [ 3302 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:43.096805 [ 3285 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:43.134645 [ 3292 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:43.422040 [ 3281 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:43.792992 [ 3260 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:43.805469 [ 3248 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:43.957279 [ 3243 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:44.097871 [ 3253 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:44.136105 [ 3259 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:44.422919 [ 3247 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:44.793978 [ 3230 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:44.806375 [ 3224 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:44.958689 [ 3218 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:45.099014 [ 3221 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:45.137456 [ 3217 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:45.424406 [ 3206 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:45.795014 [ 3193 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:45.807212 [ 3199 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:45.959847 [ 3189 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:46.100455 [ 3181 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:46.138777 [ 3186 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:46.425701 [ 3188 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:46.796535 [ 3183 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:46.808513 [ 3171 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:46.960978 [ 3167 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:47.101579 [ 3156 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:47.140701 [ 3160 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:47.427431 [ 3151 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:47.797787 [ 3144 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:47.809709 [ 3147 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:47.962274 [ 3145 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:48.102676 [ 3137 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:48.142047 [ 3149 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:48.429107 [ 3123 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:48.799165 [ 3130 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:48.810824 [ 3108 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:48.963202 [ 3107 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:49.104010 [ 3103 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:49.143088 [ 3132 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:49.430198 [ 3110 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:49.800710 [ 3082 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:49.812077 [ 3094 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:49.964150 [ 3087 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:50.104936 [ 3075 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:50.144196 [ 3085 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:50.431096 [ 3079 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:50.802056 [ 3077 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:50.813106 [ 3059 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:50.965122 [ 3060 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:51.106155 [ 3065 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:51.145256 [ 3055 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:51.432071 [ 3057 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:51.803358 [ 3296 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:51.814306 [ 3265 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:51.966223 [ 3203 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:52.107232 [ 3329 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:52.146433 [ 3141 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:52.433039 [ 3564 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:52.804934 [ 3560 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:52.815547 [ 3544 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:52.967365 [ 3535 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:53.108575 [ 3541 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:53.176130 [ 3545 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:53.433901 [ 3530 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:53.806177 [ 3519 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:53.817201 [ 3547 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:53.968459 [ 3275 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:54.109706 [ 3522 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:54.177474 [ 3507 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:54.434831 [ 3513 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:54.807554 [ 3488 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:54.818831 [ 3495 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:54.969242 [ 3504 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:55.110750 [ 3476 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:55.178622 [ 3479 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:55.436006 [ 3489 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:55.809070 [ 3472 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:55.820280 [ 3487 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:55.970271 [ 3463 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:56.111762 [ 3452 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:56.179989 [ 3455 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:56.437225 [ 3459 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:56.810453 [ 3456 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:56.821520 [ 3437 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:56.971452 [ 3431 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:57.112766 [ 3434 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:57.181111 [ 3438 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:57.438658 [ 3451 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:57.812066 [ 3417 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:57.822684 [ 3419 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:57.972971 [ 3421 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:58.113582 [ 3395 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:58.182016 [ 3404 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:58.440003 [ 3389 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:58.813376 [ 3367 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:58.823896 [ 3374 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:58.974268 [ 3376 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:59.114638 [ 3385 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:59.182977 [ 3364 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:59.441731 [ 3351 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:59.815651 [ 3326 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:59.825093 [ 3365 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:59.975203 [ 3357 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:00.115636 [ 3334 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:00.184020 [ 3373 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:00.443175 [ 3330 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:00.570856 [ 3647 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {c84fffe3-f7b9-426e-917b-60cee886efa2::202510_1_231_56}: 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 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) @ 0x0000000039c89948 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000003999bfb7 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 @ 0x00000000399942f0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000039d15c04 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&) @ 0x0000000039d20399 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) @ 0x0000000039d1c606 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000396308a4 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x00000000396235dd 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000003963b3e0 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x00000000396504a0 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3c455d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:00.817065 [ 3313 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:00.826104 [ 3355 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:00.873226 [ 3683 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {186f5ff7-8555-45f7-9ef8-8ad4e96d3e41::lambda}: 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dc50b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::clearPartsFromFilesystemImpl(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>*) @ 0x0000000039746581 8. ./contrib/llvm-project/libcxx/include/__hash_table:935: DB::MergeTreeData::clearPartsFromFilesystem(std::vector, std::allocator>> const&, bool, std::unordered_set, std::equal_to, std::allocator>*) @ 0x000000003973f352 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::clearOldPartsFromFilesystem(bool) @ 0x000000003973ec5c 10. ./build_docker/./src/Storages/StorageMergeTree.cpp:1478: bool std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003a381fbb 11. ./src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x0000000038b24677 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396a2913 13. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396a45f9 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b393f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 16. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 20. ? @ 0x00007f100c857ac3 21. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:00.976001 [ 3321 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:01.116842 [ 3348 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:01.185246 [ 3309 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:01.538345 [ 3325 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:01.781704 [ 3655 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {c84fffe3-f7b9-426e-917b-60cee886efa2::202510_1_231_56}: 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000002009b98d 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x000000002009675f 5. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:129: CurrentMemoryTracker::injectFault() @ 0x000000001ff7d1df 6. ./build_docker/./src/Common/ThreadFuzzer.cpp:270: DB::ThreadFuzzer::maybeInjectMemoryLimitException() @ 0x000000002011909f 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:151: DB::MergePlainMergeTreeTask::finish() @ 0x000000003a3c7732 8. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3c4534 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:01.818491 [ 3285 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:01.826953 [ 3292 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:01.976895 [ 3283 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:02.118047 [ 3310 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:02.186396 [ 3273 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:02.539501 [ 3255 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:02.820232 [ 3271 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:02.828037 [ 3262 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:02.977834 [ 3256 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:03.119237 [ 3254 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:03.187220 [ 3259 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:03.540924 [ 3239 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:03.821438 [ 3224 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:03.829030 [ 3258 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:03.978852 [ 3218 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:04.120132 [ 3217 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:04.232572 [ 3212 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:04.541997 [ 3204 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:04.822397 [ 3205 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:04.830327 [ 3219 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:04.979948 [ 3189 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:05.121092 [ 3238 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:05.233822 [ 3181 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:05.543004 [ 3180 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:05.823439 [ 3171 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:05.831455 [ 3175 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:05.980851 [ 3166 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:06.122209 [ 3169 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:06.235272 [ 3153 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:06.572581 [ 3163 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:06.832991 [ 3145 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:06.922553 [ 3134 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:06.981839 [ 3146 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:07.122962 [ 3121 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:07.236746 [ 3126 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:07.573712 [ 3125 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:07.834153 [ 3140 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:07.923910 [ 3116 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:07.983033 [ 3120 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:08.124286 [ 3108 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:08.237961 [ 3113 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:08.574918 [ 3096 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:08.835167 [ 3105 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:08.925165 [ 3084 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:08.984550 [ 3078 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:09.125625 [ 3095 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:09.239425 [ 3090 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:09.576088 [ 3104 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:09.836457 [ 3055 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:09.926578 [ 3073 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:09.985459 [ 3396 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:10.126590 [ 3391 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:10.241239 [ 3418 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:10.577132 [ 3322 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:10.837649 [ 3098 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:10.928137 [ 3201 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:10.986915 [ 3538 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:11.127413 [ 3561 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:11.242576 [ 3544 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:11.578608 [ 3528 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:11.838632 [ 3545 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:11.929710 [ 3566 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:11.988647 [ 3532 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:12.129094 [ 3549 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:12.244400 [ 3519 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:12.580033 [ 3539 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:12.840239 [ 3510 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:12.931087 [ 3522 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:12.989628 [ 3520 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:13.130131 [ 3508 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:13.245555 [ 3500 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:13.581493 [ 3494 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:13.841440 [ 3476 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:13.932545 [ 3479 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:13.991550 [ 3491 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:14.131043 [ 3475 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:14.246766 [ 3480 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:14.582481 [ 3460 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:14.842386 [ 3455 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:14.933982 [ 3467 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:15.077921 [ 3458 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:15.132050 [ 3453 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:15.248348 [ 3447 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:15.584010 [ 3423 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:15.843580 [ 3438 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:15.935502 [ 3426 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:16.079211 [ 3445 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:16.133290 [ 3420 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:16.249657 [ 3417 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:16.585102 [ 3409 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:16.844765 [ 3395 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:16.937052 [ 3399 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:17.080480 [ 3392 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:17.134649 [ 3474 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:17.251056 [ 3387 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:17.586058 [ 3389 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:17.846085 [ 3388 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:17.938431 [ 3367 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:18.081729 [ 3381 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:18.135915 [ 3402 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:18.252652 [ 3375 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:18.461957 [ 32712 ] {a794f077-1ad6-4df1-917b-7160558a1305} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, jobs=2): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:43544) (comment: 01396_inactive_replica_cleanup_nodes_zookeeper.sh) (in query: SELECT sum(toUInt32(extract(message, 'Removed (\d+) old log entries'))) FROM system.text_log WHERE event_date >= yesterday() AND logger_name LIKE '%' || 'test_uttb102q' || '%r1%(ReplicatedMergeTreeCleanupThread)%' AND message LIKE '%Removed % old log entries%'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000039d07892 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&) @ 0x0000000039d09d4a 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:63: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x00000000326402a2 12. ./build_docker/./src/DataTypes/Serializations/SerializationLowCardinality.cpp:59: DB::SerializationLowCardinality::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000003274547e 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000032640cad 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000039d01224 15. ./contrib/llvm-project/libcxx/include/vector:547: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000039d00b49 16. ./contrib/llvm-project/libcxx/include/__tree:1088: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) @ 0x00000000399bb1c8 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 @ 0x00000000399b0254 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039d46d05 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003bfd663a 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c083c53 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003bfe2b53 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d3c440 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf89b85 24. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 25. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 29. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 2025.10.23 23:55:18.505754 [ 32712 ] {a794f077-1ad6-4df1-917b-7160558a1305} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, jobs=2): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000039d07892 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&) @ 0x0000000039d09d4a 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:63: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x00000000326402a2 12. ./build_docker/./src/DataTypes/Serializations/SerializationLowCardinality.cpp:59: DB::SerializationLowCardinality::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000003274547e 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000032640cad 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000039d01224 15. ./contrib/llvm-project/libcxx/include/vector:547: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000039d00b49 16. ./contrib/llvm-project/libcxx/include/__tree:1088: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) @ 0x00000000399bb1c8 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 @ 0x00000000399b0254 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039d46d05 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003bfd663a 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c083c53 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003bfe2b53 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d3c440 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf89b85 24. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 25. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 29. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 2025.10.23 23:55:18.586948 [ 3365 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:18.847443 [ 3334 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:18.940141 [ 3315 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:19.082684 [ 3361 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:19.136774 [ 3324 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:19.253998 [ 3305 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:19.588466 [ 3313 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:19.848846 [ 3321 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:19.941566 [ 3298 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:20.137608 [ 3309 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:20.137918 [ 3311 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:20.255419 [ 3302 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:20.589635 [ 3288 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:20.850256 [ 3277 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:20.942910 [ 3272 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:21.138600 [ 3266 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:21.139212 [ 3295 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:21.256887 [ 3255 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:21.590756 [ 3260 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:21.851644 [ 3254 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:21.944440 [ 3249 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:22.140025 [ 3247 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:22.140394 [ 3227 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:22.258433 [ 3241 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:22.592199 [ 3224 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:22.853088 [ 3237 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:22.945706 [ 3222 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:23.141518 [ 3214 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:23.141703 [ 3225 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:23.259896 [ 3210 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:23.593347 [ 3199 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:23.854234 [ 3238 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:23.947065 [ 3186 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:24.142705 [ 3182 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:24.142884 [ 3187 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:24.261442 [ 3188 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:24.594508 [ 3173 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:24.855653 [ 3215 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:24.948506 [ 3160 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:25.143978 [ 3153 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:25.143978 [ 3151 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:25.262851 [ 3155 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:25.595852 [ 3144 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:25.857296 [ 3145 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:25.949882 [ 3134 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:26.144947 [ 3121 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:26.144957 [ 3149 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:26.264334 [ 3143 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:26.597186 [ 3138 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:26.858635 [ 3123 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:26.951286 [ 3140 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:27.145885 [ 3131 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:27.145987 [ 3127 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:27.265692 [ 3112 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:27.598392 [ 3106 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:27.860428 [ 3122 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:27.952971 [ 3091 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:28.147102 [ 3083 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:28.148271 [ 3083 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:28.266793 [ 3084 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:28.599412 [ 3064 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:28.861722 [ 3444 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:28.954501 [ 3427 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:29.148383 [ 3396 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:29.149324 [ 3443 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:29.268182 [ 3391 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:29.431126 [ 32712 ] {ad9d9291-ac86-4b58-b1c4-65b281e6edf4} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, jobs=2): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:47108) (comment: 01396_inactive_replica_cleanup_nodes_zookeeper.sh) (in query: SELECT sum(toUInt32(extract(message, 'Removed (\d+) old log entries'))) FROM system.text_log WHERE event_date >= yesterday() AND logger_name LIKE '%' || 'test_uttb102q' || '%r1%(ReplicatedMergeTreeCleanupThread)%' AND message LIKE '%Removed % old log entries%'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000039d07892 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&) @ 0x0000000039d09d4a 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000032745572 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000032640cad 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000039d01224 14. ./contrib/llvm-project/libcxx/include/vector:547: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000039d00b49 15. ./contrib/llvm-project/libcxx/include/__tree:1088: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) @ 0x00000000399bb1c8 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 @ 0x00000000399b0254 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039d46d05 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003bfd663a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c083c53 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003bfe2b53 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d3c440 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf89b85 23. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 24. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 28. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 31. ? @ 0x00007f100c857ac3 2025.10.23 23:55:29.491347 [ 32712 ] {ad9d9291-ac86-4b58-b1c4-65b281e6edf4} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, jobs=2): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000039d07892 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&) @ 0x0000000039d09d4a 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000032745572 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000032640cad 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000039d01224 14. ./contrib/llvm-project/libcxx/include/vector:547: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000039d00b49 15. ./contrib/llvm-project/libcxx/include/__tree:1088: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) @ 0x00000000399bb1c8 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 @ 0x00000000399b0254 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039d46d05 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003bfd663a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c083c53 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003bfe2b53 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d3c440 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf89b85 23. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 24. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 28. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 31. ? @ 0x00007f100c857ac3 2025.10.23 23:55:29.600445 [ 3296 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:29.863276 [ 3291 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:29.956214 [ 3563 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:30.149736 [ 3124 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:30.150601 [ 3071 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:30.269669 [ 3141 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:30.601626 [ 3564 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:30.865202 [ 3542 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:30.957585 [ 3560 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:31.151076 [ 3559 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:31.227142 [ 3544 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:31.270918 [ 3527 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:31.602805 [ 3236 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:31.866441 [ 3549 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:31.958990 [ 3546 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:32.152475 [ 3521 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:32.228447 [ 3514 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:32.272936 [ 3515 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:32.603914 [ 3499 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:32.867729 [ 3509 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:32.960419 [ 3513 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:33.153809 [ 3498 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:33.229570 [ 3063 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:33.274471 [ 3504 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:33.605041 [ 3490 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:33.869280 [ 3475 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:33.961686 [ 3469 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:34.154888 [ 3461 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:34.230857 [ 3471 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:34.275686 [ 3478 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:34.606204 [ 3459 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:34.870888 [ 3462 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:34.963150 [ 3466 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:35.156468 [ 3442 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:35.232429 [ 3450 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:35.277240 [ 3441 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:35.607677 [ 3423 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:35.872402 [ 3432 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:35.964608 [ 3533 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:36.157557 [ 3451 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:36.233816 [ 3424 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:36.278692 [ 3417 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:36.609031 [ 3411 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:36.873776 [ 3414 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:36.965866 [ 3412 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:37.158701 [ 3407 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:37.234992 [ 3399 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:37.280238 [ 3416 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:37.610440 [ 3390 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:37.875445 [ 3394 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:37.967404 [ 3386 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:38.160291 [ 3380 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:38.236453 [ 3398 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:38.281396 [ 3375 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:38.612182 [ 3359 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:38.877365 [ 3339 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:38.969196 [ 3354 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:39.161420 [ 3334 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:39.237621 [ 3373 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:39.282623 [ 3342 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:39.613386 [ 3330 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:39.878899 [ 3358 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:39.970849 [ 3297 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:40.162436 [ 3301 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:40.239033 [ 3321 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:40.284192 [ 3335 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:40.614491 [ 3356 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:40.880792 [ 3325 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:40.972504 [ 3308 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:41.163418 [ 3290 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:41.240567 [ 3299 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:41.285494 [ 3287 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:41.398254 [ 3654 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {d60c8165-1f8c-4cd1-8084-8b8c63363ea3::202510_99_197_62}: 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000002009b98d 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x000000002009675f 5. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:129: CurrentMemoryTracker::injectFault() @ 0x000000001ff7d1df 6. ./build_docker/./src/Common/ThreadFuzzer.cpp:270: DB::ThreadFuzzer::maybeInjectMemoryLimitException() @ 0x000000002011909f 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:151: DB::MergePlainMergeTreeTask::finish() @ 0x000000003a3c7732 8. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3c4534 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:41.616283 [ 3283 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:41.882225 [ 3257 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:41.973649 [ 3270 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:42.165179 [ 3267 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:42.241892 [ 3251 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:42.286556 [ 3260 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:42.617722 [ 3249 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:42.883658 [ 3242 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:42.974837 [ 3233 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:43.166499 [ 3227 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:43.242989 [ 3226 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:43.288084 [ 3229 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:43.619200 [ 3218 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:43.885240 [ 3190 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:43.976376 [ 3204 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:44.167542 [ 3199 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:44.244106 [ 3219 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:44.289611 [ 3184 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:44.620248 [ 3182 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:44.886657 [ 3180 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:44.977669 [ 3173 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:45.169062 [ 3183 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:45.245254 [ 3167 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:45.291157 [ 3166 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:45.621349 [ 3158 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:45.888969 [ 3161 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:45.979211 [ 3517 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:46.170216 [ 3133 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:46.246381 [ 3152 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:46.292402 [ 3154 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:46.622654 [ 3149 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:46.890755 [ 3118 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:46.981140 [ 3128 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:47.171266 [ 3164 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:47.247530 [ 3136 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:47.293626 [ 3129 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:47.624154 [ 3131 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:47.892699 [ 3159 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:47.982659 [ 3113 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:48.172764 [ 3109 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:48.249150 [ 3106 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:48.294939 [ 3100 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:48.625434 [ 3075 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:48.894177 [ 3079 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:48.984097 [ 3095 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:49.174248 [ 3077 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:49.250434 [ 3059 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:49.296519 [ 3064 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:49.626465 [ 3396 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:49.895442 [ 3054 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:49.985501 [ 3418 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:50.175491 [ 3203 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:50.251615 [ 3563 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:50.297783 [ 3197 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:50.627360 [ 3135 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:50.896765 [ 3061 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:50.986640 [ 3213 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:51.176800 [ 3559 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:51.252741 [ 3556 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:51.298846 [ 3544 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:51.628752 [ 3565 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:51.897894 [ 3532 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:51.988105 [ 3207 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:52.177932 [ 3546 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:52.253845 [ 3516 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:52.300107 [ 3547 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:52.629953 [ 3275 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:52.899308 [ 3507 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:52.989408 [ 3500 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:53.179057 [ 3497 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:53.254912 [ 3513 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:53.301469 [ 3488 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:53.631344 [ 3486 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:53.900893 [ 3489 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:53.990759 [ 3475 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:54.180493 [ 3480 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:54.262479 [ 3468 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:54.302784 [ 3461 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:54.718860 [ 3465 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:54.902108 [ 3467 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:54.992220 [ 3458 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:55.181428 [ 3449 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:55.263494 [ 3470 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:55.304062 [ 3437 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:55.720436 [ 3434 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:55.903592 [ 3438 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:55.993619 [ 3425 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:56.182726 [ 3451 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:56.264578 [ 3422 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:56.305426 [ 3417 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:56.721727 [ 3393 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:56.905583 [ 3407 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:56.995102 [ 3416 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:57.259252 [ 3384 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:57.266018 [ 3474 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:57.306788 [ 3390 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:57.723098 [ 3413 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:57.906874 [ 3367 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:57.996565 [ 3383 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:58.260481 [ 3379 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:58.267193 [ 3351 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:58.308532 [ 3354 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:58.724464 [ 3342 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:58.908388 [ 3338 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:58.998073 [ 3324 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:59.261721 [ 3303 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:59.339581 [ 3358 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:59.340106 [ 3304 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:59.725728 [ 3301 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:59.909841 [ 3309 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:59.999507 [ 3340 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:00.262977 [ 3302 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:00.341209 [ 3294 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:00.341286 [ 3317 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:00.727023 [ 3279 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:00.911240 [ 3268 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:01.001105 [ 3263 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:01.264308 [ 3267 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:01.342360 [ 3251 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:01.342458 [ 3250 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:01.728350 [ 3243 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:01.912449 [ 3249 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:02.002311 [ 3233 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:02.265359 [ 3224 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:02.343262 [ 3229 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:02.343523 [ 3258 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:02.729590 [ 3222 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:02.913593 [ 3217 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:03.003544 [ 3211 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:03.266446 [ 3209 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:03.344614 [ 3199 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:03.345020 [ 3202 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:03.730972 [ 3186 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:03.914984 [ 3188 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:04.005268 [ 3180 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:04.267552 [ 3215 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:04.345873 [ 3158 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:04.346382 [ 3156 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:04.774354 [ 3148 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:04.916390 [ 3161 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:05.006370 [ 3517 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:05.268925 [ 3152 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:05.346839 [ 3145 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:05.347432 [ 3134 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:05.775454 [ 3126 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:05.917422 [ 3125 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:06.007403 [ 3115 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:06.270036 [ 3123 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:06.348466 [ 3140 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:06.348939 [ 3114 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:06.776475 [ 3113 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:06.918927 [ 3103 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:07.008787 [ 3132 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:07.271432 [ 3110 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:07.349767 [ 3102 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:07.350131 [ 3091 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:07.777497 [ 3076 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:07.920420 [ 3105 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:08.009928 [ 3079 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:08.272772 [ 3064 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:08.351133 [ 3068 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:08.351177 [ 3069 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:08.778956 [ 3319 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:08.921399 [ 3203 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:08.928327 [ 3650 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {eca3dc2f-d725-4477-8dd8-6130f79f34c3::202510_1_68_19_18}: 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 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) @ 0x0000000039c89948 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000003999bfb7 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 @ 0x00000000399942f0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000039d15c04 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&) @ 0x0000000039d20399 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) @ 0x0000000039d1c606 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000396308a4 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x00000000396235dd 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000003963b3e0 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x00000000396504a0 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3c455d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:09.010843 [ 3071 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:09.273607 [ 3551 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:09.352514 [ 3542 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:09.352536 [ 3561 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:09.780552 [ 3556 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:09.922349 [ 3535 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:10.012133 [ 3555 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:10.274451 [ 3548 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:10.353901 [ 3558 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:10.353931 [ 3566 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:10.781795 [ 3525 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:10.923659 [ 3074 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:11.013544 [ 3511 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:11.349968 [ 3275 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:11.355527 [ 3520 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:11.355586 [ 3522 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:11.783035 [ 3513 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:11.925228 [ 3363 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:12.015212 [ 3063 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:12.351023 [ 3476 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:12.356880 [ 3512 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:12.357441 [ 3490 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:12.784330 [ 3475 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:12.926347 [ 3469 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:13.017095 [ 3479 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:13.352167 [ 3462 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:13.358067 [ 3464 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:13.358576 [ 3466 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:13.785528 [ 3456 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:13.927669 [ 3431 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:14.018536 [ 3423 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:14.353201 [ 3426 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:14.359109 [ 3425 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:14.359656 [ 3445 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:14.786538 [ 3417 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:14.929079 [ 3419 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:15.020080 [ 3411 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:15.354162 [ 3407 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:15.360005 [ 3405 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:15.360777 [ 3399 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:15.787792 [ 3401 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:15.930548 [ 3380 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:16.021624 [ 3388 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:16.247298 [ 32712 ] {b4122699-7dff-4048-931c-9f5782de8f6d} 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.10542.altinitytest (altinity build)) (from [::1]:42694) (comment: 01396_inactive_replica_cleanup_nodes_zookeeper.sh) (in query: SELECT sum(toUInt32(extract(message, 'Removed (\d+) old log entries'))) FROM system.text_log WHERE event_date >= yesterday() AND logger_name LIKE '%' || 'test_uttb102q' || '%r1%(ReplicatedMergeTreeCleanupThread)%' AND message LIKE '%Removed % old log entries%'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000039d07892 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&) @ 0x0000000039d09d4a 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:63: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x00000000326402a2 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000032640cad 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000039d01224 14. ./contrib/llvm-project/libcxx/include/vector:547: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000039d00b49 15. ./contrib/llvm-project/libcxx/include/__tree:1088: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) @ 0x00000000399bb1c8 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 @ 0x00000000399b0254 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039d46d05 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003bfd663a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c083c53 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003bfe2b53 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d3c440 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf89b85 23. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 24. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 28. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 31. ? @ 0x00007f100c857ac3 2025.10.23 23:56:16.253285 [ 32712 ] {b4122699-7dff-4048-931c-9f5782de8f6d} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000039d07892 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&) @ 0x0000000039d09d4a 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:63: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x00000000326402a2 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000032640cad 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000039d01224 14. ./contrib/llvm-project/libcxx/include/vector:547: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000039d00b49 15. ./contrib/llvm-project/libcxx/include/__tree:1088: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) @ 0x00000000399bb1c8 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 @ 0x00000000399b0254 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039d46d05 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003bfd663a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c083c53 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003bfe2b53 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d3c440 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf89b85 23. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 24. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 28. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 31. ? @ 0x00007f100c857ac3 2025.10.23 23:56:16.355224 [ 3367 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:16.360899 [ 3374 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:16.361769 [ 3383 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:16.788713 [ 3379 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:16.932007 [ 3370 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:17.022871 [ 3352 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:17.356335 [ 3346 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:17.361786 [ 3341 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:17.362717 [ 3347 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:17.789786 [ 3342 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:17.933259 [ 3330 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:18.024146 [ 3305 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:18.357770 [ 3311 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:18.362786 [ 3340 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:18.364293 [ 3325 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:18.791070 [ 3287 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:18.934865 [ 3279 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:19.025389 [ 3283 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:19.359219 [ 3261 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:19.364178 [ 3257 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:19.365503 [ 3268 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:19.792542 [ 3270 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:19.936515 [ 3263 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:20.026887 [ 3271 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:20.360771 [ 3243 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:20.365492 [ 3254 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:20.366772 [ 3244 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:20.793981 [ 3259 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:20.937922 [ 3231 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:21.028402 [ 3228 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:21.362203 [ 3224 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:21.366772 [ 3230 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:21.368077 [ 3229 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:21.795122 [ 3221 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:21.939497 [ 3225 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:22.029626 [ 3214 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:22.363373 [ 3200 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:22.368130 [ 3204 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:22.369415 [ 3198 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:22.796370 [ 3189 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:22.941106 [ 3184 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:23.031104 [ 3238 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:23.364537 [ 3188 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:23.369413 [ 3165 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:23.370738 [ 3180 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:23.797501 [ 3178 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:23.942614 [ 3160 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:24.032476 [ 3169 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:24.365715 [ 3139 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:24.370859 [ 3144 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:24.372178 [ 3133 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:24.798446 [ 3134 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:24.944409 [ 3142 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:25.033590 [ 3121 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:25.366662 [ 3128 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:25.372398 [ 3115 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:25.373683 [ 3157 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:25.799479 [ 3108 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:25.945959 [ 3159 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:26.034770 [ 3103 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:26.368240 [ 3101 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:26.373491 [ 3117 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:26.375086 [ 3122 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:26.801091 [ 3076 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:26.947390 [ 3075 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:27.036154 [ 3092 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:27.369199 [ 3069 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:27.374489 [ 3060 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:27.376451 [ 3056 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:27.802335 [ 3073 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:27.948742 [ 3067 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:28.037493 [ 3319 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:28.370257 [ 3135 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:28.375948 [ 3168 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:28.377684 [ 3061 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:28.803357 [ 3536 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:28.949993 [ 3550 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:29.038899 [ 3556 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:29.371522 [ 3565 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:29.377227 [ 3545 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:29.378847 [ 3548 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:29.804377 [ 3530 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:29.951267 [ 3525 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:30.040563 [ 3546 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:30.372870 [ 3521 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:30.378423 [ 3523 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:30.380373 [ 3514 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:30.805550 [ 3522 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:30.952891 [ 3499 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:31.041852 [ 3503 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:31.374153 [ 3513 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:31.380259 [ 3498 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:31.381584 [ 3496 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:31.808482 [ 3482 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:31.954368 [ 3481 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:32.043003 [ 3512 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:32.375301 [ 3475 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:32.381501 [ 3477 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:32.382856 [ 3485 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:32.932236 [ 3463 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:32.955616 [ 3460 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:33.044477 [ 3455 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:33.376564 [ 3449 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:33.382784 [ 3447 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:33.384194 [ 3470 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:33.933409 [ 3434 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:33.957165 [ 3454 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:34.046096 [ 3438 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:34.377845 [ 3451 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:34.384279 [ 3420 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:34.385350 [ 3424 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:34.934500 [ 3399 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:34.958503 [ 3416 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:35.048067 [ 3392 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:35.378811 [ 3394 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:35.385179 [ 3387 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:35.386799 [ 3401 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:35.935889 [ 3383 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:35.960070 [ 3381 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:36.049347 [ 3366 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:36.380211 [ 3379 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:36.386229 [ 3382 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:36.388491 [ 3351 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:36.937131 [ 3328 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:36.961397 [ 3334 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:37.051145 [ 3315 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:37.381619 [ 3330 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:37.387201 [ 3318 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:37.389673 [ 3323 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:37.938362 [ 3321 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:37.962697 [ 3335 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:38.052727 [ 3314 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:38.382743 [ 3312 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:38.388568 [ 3285 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:38.390627 [ 3292 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:38.939957 [ 3273 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:38.964280 [ 3276 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:39.053856 [ 3257 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:39.384233 [ 3251 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:39.389916 [ 3250 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:39.392025 [ 3260 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:39.942150 [ 3244 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:39.965740 [ 3253 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:40.054946 [ 3249 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:40.385469 [ 3247 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:40.391002 [ 3241 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:40.393037 [ 3228 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:40.943077 [ 3230 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:40.966918 [ 3258 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:41.056179 [ 3220 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:41.386487 [ 3217 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:41.391970 [ 3210 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:41.394221 [ 3214 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:41.944557 [ 3198 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:41.968189 [ 3208 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:42.057448 [ 3205 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:42.387564 [ 3192 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:42.393166 [ 3238 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:42.395475 [ 3181 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:42.945558 [ 3188 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:42.969263 [ 3165 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:43.058521 [ 3183 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:43.388913 [ 3169 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:43.394196 [ 3153 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:43.396814 [ 3151 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:43.946302 [ 3146 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:43.970280 [ 3137 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:44.059659 [ 3149 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:44.390066 [ 3119 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:44.395390 [ 3164 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:44.398503 [ 3136 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:44.947336 [ 3130 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:44.971500 [ 3113 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:45.061076 [ 3107 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:45.391359 [ 3101 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:45.396727 [ 3117 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:45.400175 [ 3122 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:45.948862 [ 3088 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:45.973217 [ 3087 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:46.062539 [ 3076 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:46.392732 [ 3059 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:46.398011 [ 3058 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:46.401501 [ 3081 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:46.950160 [ 3065 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:46.974596 [ 3066 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:47.064475 [ 3073 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:47.393987 [ 3418 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:47.399298 [ 3433 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:47.403012 [ 3296 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:47.951635 [ 3329 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:47.976113 [ 3562 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:48.066024 [ 3168 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:48.395114 [ 3544 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:48.400205 [ 3527 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:48.404474 [ 3529 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:48.953007 [ 3532 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:48.977287 [ 3554 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:49.067478 [ 3531 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:49.470105 [ 3074 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:49.470216 [ 3521 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:49.470318 [ 3519 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:49.954268 [ 3522 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:49.978493 [ 3520 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:50.069691 [ 3508 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:50.471319 [ 3500 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:50.471523 [ 3513 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:50.471653 [ 3497 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:50.979990 [ 3494 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:50.955647 [ 3063 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:51.071329 [ 3504 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:51.472751 [ 3512 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:51.473070 [ 3490 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:51.473268 [ 3484 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:51.981535 [ 3480 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:52.015014 [ 3472 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:52.072956 [ 3471 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:52.474137 [ 3459 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:52.474325 [ 3457 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:52.474355 [ 3455 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:52.983053 [ 3464 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:53.016166 [ 3447 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:53.074311 [ 3437 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:53.475326 [ 3533 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:53.475332 [ 3425 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:53.475572 [ 3426 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:53.984448 [ 3409 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:54.017307 [ 3415 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:54.075943 [ 3395 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:54.476478 [ 3408 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:54.476533 [ 3392 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:54.476984 [ 3384 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:54.985496 [ 3398 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:55.018421 [ 3388 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:55.076963 [ 3377 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:55.477585 [ 3402 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:55.477635 [ 3368 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:55.478169 [ 3375 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:55.986906 [ 3379 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:56.019559 [ 3349 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:56.078183 [ 3352 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:56.478713 [ 3316 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:56.479312 [ 3338 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:56.479415 [ 3372 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:56.988294 [ 3358 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:57.021012 [ 3306 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:57.079973 [ 3304 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:57.480568 [ 3309 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:57.480751 [ 3311 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:57.494275 [ 3331 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:58.026316 [ 3317 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:58.026376 [ 3299 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:58.081334 [ 3287 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:58.481666 [ 3261 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:58.481665 [ 3257 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:58.495121 [ 3268 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:59.027625 [ 3251 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:59.027638 [ 3250 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:59.082481 [ 3260 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:59.482821 [ 3249 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:59.482809 [ 3259 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:59.496266 [ 3242 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:00.029108 [ 3239 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:00.029190 [ 3227 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:00.084184 [ 3234 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:00.483987 [ 3220 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:00.497241 [ 3216 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:00.526506 [ 3237 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:01.030215 [ 3190 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:01.030654 [ 3212 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:01.085405 [ 3204 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:01.485025 [ 3208 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:01.498242 [ 3199 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:01.528065 [ 3202 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:02.031881 [ 3179 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:02.031962 [ 3185 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:02.086781 [ 3170 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:02.486258 [ 3167 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:02.499320 [ 3166 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:02.529357 [ 3158 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:03.033076 [ 3153 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:03.033332 [ 3151 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:03.088241 [ 3148 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:03.488808 [ 3154 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:03.500189 [ 3134 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:03.530534 [ 3142 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:04.034243 [ 3123 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:04.034776 [ 3129 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:04.089566 [ 3120 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:04.293195 [ 3647 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {c84fffe3-f7b9-426e-917b-60cee886efa2::202510_1_253_71}: 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000002009b98d 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x000000002009675f 5. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:129: CurrentMemoryTracker::injectFault() @ 0x000000001ff7d1df 6. ./build_docker/./src/Common/ThreadFuzzer.cpp:270: DB::ThreadFuzzer::maybeInjectMemoryLimitException() @ 0x000000002011909f 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:151: DB::MergePlainMergeTreeTask::finish() @ 0x000000003a3c7732 8. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3c4534 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:04.489882 [ 3132 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:04.501039 [ 3101 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:04.532272 [ 3122 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:05.035319 [ 3078 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:05.036078 [ 3080 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:05.090967 [ 3085 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:05.490747 [ 3058 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:05.501873 [ 3081 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:05.533783 [ 3077 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:06.036492 [ 3062 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:06.037225 [ 3066 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:06.092615 [ 3427 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:06.492498 [ 3054 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:06.502972 [ 3319 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:06.535223 [ 3223 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:07.038840 [ 3406 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:07.038933 [ 3329 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:07.093912 [ 3168 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:07.493729 [ 3111 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:07.504203 [ 3201 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:07.536355 [ 3561 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:08.039901 [ 3559 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:08.040314 [ 3552 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:08.095301 [ 3540 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:08.494776 [ 3554 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:08.505397 [ 3531 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:08.537581 [ 3549 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:09.040824 [ 3514 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:09.041184 [ 3515 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:09.096532 [ 3511 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:09.496002 [ 3503 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:09.506556 [ 3524 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:09.538791 [ 3509 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:10.041735 [ 3063 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:10.042012 [ 3495 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:10.097959 [ 3493 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:10.497035 [ 3483 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:10.507629 [ 3481 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:10.540093 [ 3476 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:11.042886 [ 3475 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:11.043256 [ 3477 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:11.099414 [ 3469 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:11.497911 [ 3471 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:11.508800 [ 3478 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:11.541039 [ 3463 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:12.044392 [ 3467 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:12.044842 [ 3458 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:12.101200 [ 3462 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:12.498984 [ 3429 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:12.509812 [ 3423 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:12.542451 [ 3434 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:13.047328 [ 3426 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:13.047379 [ 3445 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:13.102538 [ 3422 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:13.500338 [ 3407 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:13.510835 [ 3399 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:13.543722 [ 3416 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:14.048692 [ 3378 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:14.048917 [ 3374 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:14.104273 [ 3383 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:14.501568 [ 3379 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:14.512313 [ 3382 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:14.545035 [ 3370 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:15.049898 [ 3315 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:15.050207 [ 3334 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:15.105516 [ 3333 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:15.503076 [ 3320 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:15.513488 [ 3324 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:15.546402 [ 3330 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:16.051298 [ 3355 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:16.051757 [ 3350 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:16.106829 [ 3327 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:16.504342 [ 3340 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:16.514610 [ 3307 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:16.621466 [ 3300 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:17.053796 [ 3288 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:17.054002 [ 3279 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:17.108542 [ 3283 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:17.505769 [ 3280 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:17.516181 [ 3281 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:17.623149 [ 3273 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:18.054651 [ 3255 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:18.055626 [ 3263 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:18.109630 [ 3252 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:18.506928 [ 3259 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:18.517643 [ 3242 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:18.625074 [ 3228 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:19.055500 [ 3216 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:19.057450 [ 3237 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:19.110983 [ 3222 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:19.507966 [ 3206 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:19.518622 [ 3211 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:19.626400 [ 3204 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:20.058820 [ 3191 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:20.112144 [ 3189 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:20.112169 [ 3184 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:20.509067 [ 3185 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:20.519933 [ 3187 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:20.628153 [ 3182 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:21.060447 [ 3166 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:21.113212 [ 3158 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:21.113287 [ 3156 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:21.509902 [ 3139 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:21.520994 [ 3163 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:21.629503 [ 3147 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:22.061608 [ 3121 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:22.114322 [ 3126 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:22.114579 [ 3162 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:22.511103 [ 3115 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:22.522065 [ 3157 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:22.630849 [ 3123 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:23.062930 [ 3127 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:23.141673 [ 3130 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:23.141688 [ 3108 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:23.512549 [ 3086 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:23.523111 [ 3075 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:23.632111 [ 3080 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:24.064578 [ 3077 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:24.142858 [ 3068 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:24.142973 [ 3104 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:24.513689 [ 3065 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:24.524391 [ 3055 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:24.633382 [ 3427 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:25.065867 [ 3223 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:25.144308 [ 3435 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:25.144317 [ 3265 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:25.514984 [ 3071 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:25.525463 [ 3141 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:25.636721 [ 3406 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:26.067389 [ 3564 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:26.145484 [ 3201 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:26.145605 [ 3111 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:26.516002 [ 3540 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:26.526436 [ 3556 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:26.638114 [ 3544 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:27.069046 [ 3566 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:27.146468 [ 3554 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:27.146852 [ 3236 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:27.516857 [ 3537 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:27.527507 [ 3074 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:27.639256 [ 3523 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:28.069919 [ 3510 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:28.147648 [ 3507 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:28.227653 [ 3508 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:28.517875 [ 3494 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:28.529202 [ 3063 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:28.640298 [ 3492 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:29.071242 [ 3491 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:29.149044 [ 3477 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:29.229227 [ 3469 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:29.519165 [ 3461 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:29.530344 [ 3471 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:29.641626 [ 3459 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:30.072826 [ 3465 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:30.150494 [ 3458 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:30.230703 [ 3466 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:30.520395 [ 3442 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:30.531277 [ 3431 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:30.642982 [ 3423 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:31.074301 [ 3420 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:31.151827 [ 3422 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:31.231850 [ 3414 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:31.522883 [ 3397 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:31.532352 [ 3384 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:31.644397 [ 3387 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:32.075669 [ 3374 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:32.153310 [ 3383 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:32.232843 [ 3381 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:32.524409 [ 3359 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:32.533589 [ 3379 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:32.645757 [ 3349 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:33.076864 [ 3357 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:33.154943 [ 3347 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:33.234005 [ 3315 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:33.525747 [ 3323 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:33.534868 [ 3305 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:33.647172 [ 3306 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:34.078229 [ 3321 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:34.156716 [ 3298 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:34.235162 [ 3356 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:34.526865 [ 3300 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:34.536103 [ 3290 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:34.649029 [ 3299 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:35.079528 [ 3284 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:35.158274 [ 3278 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:35.236503 [ 3310 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:35.528206 [ 3261 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:35.537293 [ 3257 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:35.650611 [ 3264 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:36.081157 [ 3262 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:36.160095 [ 3260 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:36.237448 [ 3250 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:36.529420 [ 3246 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:36.538239 [ 3253 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:36.652668 [ 3259 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:37.082487 [ 3226 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:37.161473 [ 3234 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:37.238542 [ 3235 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:37.530701 [ 3258 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:37.539482 [ 3220 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:37.654330 [ 3221 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:38.152061 [ 3206 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:38.162637 [ 3190 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:38.240445 [ 3196 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:38.531734 [ 3181 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:38.540470 [ 3194 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:38.655517 [ 3180 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:39.153338 [ 3160 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:39.164131 [ 3153 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:39.241842 [ 3151 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:39.533512 [ 3139 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:39.541493 [ 3163 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:39.656777 [ 3154 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:40.154629 [ 3149 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:40.165229 [ 3118 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:40.243033 [ 3129 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:40.534592 [ 3108 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:40.542789 [ 3130 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:40.657666 [ 3103 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:41.156204 [ 3082 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:41.166335 [ 3093 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:41.244388 [ 3088 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:41.535812 [ 3084 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:41.544442 [ 3070 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:41.658872 [ 3090 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:42.157954 [ 3065 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:42.167573 [ 3062 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:42.245815 [ 3066 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:42.537097 [ 3057 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:42.545900 [ 3067 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:42.660463 [ 3054 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:43.159283 [ 3345 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:43.169207 [ 3203 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:43.247167 [ 3071 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:43.538298 [ 3098 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:43.547003 [ 3564 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:43.661900 [ 3551 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:44.161281 [ 3534 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:44.170190 [ 3544 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:44.248641 [ 3535 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:44.539617 [ 3548 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:44.548534 [ 3545 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:44.663136 [ 3207 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:45.162797 [ 3549 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:45.171347 [ 3526 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:45.249829 [ 3516 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:45.541268 [ 3515 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:45.549562 [ 3511 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:45.664343 [ 3518 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:46.164264 [ 3507 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:46.172824 [ 3524 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:46.250967 [ 3503 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:46.542574 [ 3498 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:46.550758 [ 3502 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:46.665699 [ 3495 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:47.165382 [ 3512 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:47.174080 [ 3484 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:47.252169 [ 3491 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:47.544103 [ 3480 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:47.552269 [ 3472 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:47.666907 [ 3478 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:48.166680 [ 3467 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:48.175344 [ 3458 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:48.253213 [ 3464 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:48.545409 [ 3434 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:48.553423 [ 3440 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:48.668407 [ 3445 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:49.167922 [ 3412 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:49.176669 [ 3415 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:49.254374 [ 3405 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:49.546542 [ 3399 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:49.554567 [ 3416 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:49.669878 [ 3404 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:50.169051 [ 3377 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:50.177653 [ 3378 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:50.255556 [ 3368 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:50.555865 [ 3359 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:50.547689 [ 3364 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:50.671122 [ 3382 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:51.170165 [ 3352 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:51.179328 [ 3339 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:51.257110 [ 3365 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:51.556922 [ 3373 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:51.573434 [ 3316 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:51.672356 [ 3361 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:52.171341 [ 3332 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:52.181041 [ 3306 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:52.258279 [ 3304 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:52.558004 [ 3313 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:52.574461 [ 3355 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:52.673487 [ 3301 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:53.172808 [ 3340 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:53.182750 [ 3307 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:53.259475 [ 3302 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:53.559364 [ 3289 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:53.575548 [ 3286 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:53.674802 [ 3281 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:54.174121 [ 3274 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:54.261030 [ 3271 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:54.280929 [ 3255 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:54.560491 [ 3251 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:54.577056 [ 3256 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:54.676508 [ 3269 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:55.175360 [ 3242 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:55.262246 [ 3231 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:55.282257 [ 3247 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:55.561714 [ 3227 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:55.578200 [ 3226 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:55.677675 [ 3234 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:56.176785 [ 3237 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:56.263382 [ 3221 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:56.283471 [ 3218 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:56.562822 [ 3211 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:56.579381 [ 3190 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:56.678728 [ 3196 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:57.178090 [ 3199 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:57.264911 [ 3191 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:57.285197 [ 3189 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:57.564115 [ 3186 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:57.581085 [ 3194 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:57.679766 [ 3172 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:58.179621 [ 3215 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:58.266189 [ 3148 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:58.286270 [ 3163 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:58.565187 [ 3146 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:58.582268 [ 3142 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:58.680889 [ 3149 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:59.181209 [ 3164 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:59.267413 [ 3114 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:59.287395 [ 3116 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:59.566354 [ 3103 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:59.583623 [ 3101 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:59.682306 [ 3132 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:00.182492 [ 3122 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:00.268643 [ 3102 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:00.288712 [ 3094 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:00.567591 [ 3087 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:00.585093 [ 3083 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:00.684795 [ 3105 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:01.185106 [ 3072 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:01.269858 [ 3095 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:01.290203 [ 3092 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:01.632079 [ 3056 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:01.632257 [ 3444 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:01.686228 [ 3062 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:02.186814 [ 3418 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:02.271159 [ 3433 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:02.292614 [ 3322 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:02.633381 [ 3296 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:02.633478 [ 3265 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:02.688084 [ 3345 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:03.022724 [ 32712 ] {026ac93f-bb3c-4eab-943d-b41199233914} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, jobs=2): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:53450) (comment: 01396_inactive_replica_cleanup_nodes_zookeeper.sh) (in query: SELECT sum(toUInt32(extract(message, 'Removed (\d+) old log entries'))) FROM system.text_log WHERE event_date >= yesterday() AND logger_name LIKE '%' || 'test_uttb102q' || '%r1%(ReplicatedMergeTreeCleanupThread)%' AND message LIKE '%Removed % old log entries%'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000039d07892 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&) @ 0x0000000039d09d4a 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:63: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x00000000326402a2 12. ./build_docker/./src/DataTypes/Serializations/SerializationLowCardinality.cpp:59: DB::SerializationLowCardinality::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000003274547e 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000032640cad 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000039d01224 15. ./contrib/llvm-project/libcxx/include/vector:547: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000039d00b49 16. ./contrib/llvm-project/libcxx/include/__tree:1088: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) @ 0x00000000399bb1c8 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 @ 0x00000000399b0254 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039d46d05 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003bfd663a 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c083c53 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003bfe2b53 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d3c440 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf89b85 24. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 25. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 29. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 2025.10.23 23:58:03.028461 [ 32712 ] {026ac93f-bb3c-4eab-943d-b41199233914} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, jobs=2): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000039d07892 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&) @ 0x0000000039d09d4a 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:63: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x00000000326402a2 12. ./build_docker/./src/DataTypes/Serializations/SerializationLowCardinality.cpp:59: DB::SerializationLowCardinality::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000003274547e 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000032640cad 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000039d01224 15. ./contrib/llvm-project/libcxx/include/vector:547: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000039d00b49 16. ./contrib/llvm-project/libcxx/include/__tree:1088: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) @ 0x00000000399bb1c8 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 @ 0x00000000399b0254 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039d46d05 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003bfd663a 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c083c53 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003bfe2b53 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d3c440 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf89b85 24. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 25. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 29. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 2025.10.23 23:58:03.188528 [ 3174 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:03.272719 [ 3406 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:03.294331 [ 3538 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:03.634768 [ 3560 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:03.634828 [ 3536 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:03.689683 [ 3213 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:04.189862 [ 3555 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:04.274172 [ 3528 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:04.327471 [ 3543 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:04.636094 [ 3566 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:04.636133 [ 3558 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:04.690892 [ 3532 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:05.191297 [ 3521 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:05.275499 [ 3547 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:05.329034 [ 3515 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:05.637203 [ 3275 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:05.637242 [ 3510 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:05.692253 [ 3499 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:06.192863 [ 3513 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:06.277158 [ 3498 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:06.330415 [ 3506 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:06.638385 [ 3481 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:06.638574 [ 3483 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:06.693645 [ 3476 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:07.194109 [ 3475 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:07.278417 [ 3485 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:07.331588 [ 3480 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:07.639730 [ 3463 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:07.639909 [ 3468 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:07.695121 [ 3460 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:08.195465 [ 3467 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:08.280366 [ 3441 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:08.333373 [ 3429 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:08.640827 [ 3426 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:08.641087 [ 3436 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:08.696697 [ 3445 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:09.197384 [ 3412 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:09.281718 [ 3415 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:09.334612 [ 3410 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:09.642161 [ 3407 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:09.642321 [ 3395 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:09.698074 [ 3416 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:10.198785 [ 3398 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:10.282872 [ 3380 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:10.336208 [ 3388 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:10.643253 [ 3381 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:10.643263 [ 3369 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:10.699629 [ 3402 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:11.200439 [ 3366 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:11.284138 [ 3371 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:11.337539 [ 3364 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:11.644401 [ 3339 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:11.670971 [ 3365 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:11.701186 [ 3357 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:12.201702 [ 3316 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:12.285506 [ 3338 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:12.338822 [ 3320 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:12.645287 [ 3353 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:12.672248 [ 3313 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:12.702546 [ 3355 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:13.203109 [ 3311 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:13.286738 [ 3299 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:13.339946 [ 3317 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:13.646337 [ 3288 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:13.673435 [ 3279 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:13.704114 [ 3283 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:14.204492 [ 3252 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:14.287819 [ 3260 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:14.341208 [ 3251 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:14.647447 [ 3282 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:14.674812 [ 3243 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:14.705658 [ 3254 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:15.205707 [ 3228 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:15.288959 [ 3232 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:15.342563 [ 3235 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:15.649084 [ 3245 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:15.676348 [ 3216 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:15.707130 [ 3221 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:16.206932 [ 3204 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:16.290098 [ 3209 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:16.344595 [ 3193 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:16.650177 [ 3184 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:16.677357 [ 3192 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:16.708323 [ 3238 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:17.208322 [ 3188 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:17.291498 [ 3173 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:17.346277 [ 3180 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:17.651241 [ 3158 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:17.678504 [ 3195 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:17.709672 [ 3178 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:18.209327 [ 3148 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:18.292872 [ 3145 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:18.348175 [ 3134 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:18.652662 [ 3118 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:18.681121 [ 3125 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:18.711114 [ 3138 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:19.210481 [ 3140 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:19.294219 [ 3131 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:19.349839 [ 3112 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:19.653653 [ 3159 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:19.681953 [ 3113 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:19.712180 [ 3101 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:20.211993 [ 3091 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:20.295185 [ 3094 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:20.351417 [ 3089 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:20.655114 [ 3096 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:20.682994 [ 3088 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:20.713450 [ 3076 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:21.213446 [ 3079 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:21.296508 [ 3072 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:21.352995 [ 3090 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:21.656427 [ 3077 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:21.684525 [ 3064 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:21.714846 [ 3068 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:22.214892 [ 3391 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:22.297502 [ 3319 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:22.355012 [ 3223 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:22.657580 [ 3435 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:22.685958 [ 3563 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:22.716387 [ 3345 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:23.216576 [ 3329 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:23.299070 [ 3551 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:23.356302 [ 3362 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:23.658927 [ 3529 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:23.686996 [ 3541 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:23.717823 [ 3565 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:24.217712 [ 3525 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:24.300204 [ 3546 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:24.357581 [ 3516 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:24.660605 [ 3547 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:24.714901 [ 3514 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:24.719122 [ 3523 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:25.218813 [ 3500 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:25.301424 [ 3501 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:25.358840 [ 3363 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:25.661801 [ 3494 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:25.716363 [ 3063 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:25.720420 [ 3495 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:26.221656 [ 3490 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:26.302553 [ 3491 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:26.360251 [ 3475 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:26.662835 [ 3463 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:26.717845 [ 3468 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:26.721565 [ 3460 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:27.222855 [ 3464 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:27.303561 [ 3449 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:27.361519 [ 3456 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:27.711147 [ 3437 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:27.719418 [ 3423 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:27.722806 [ 3432 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:28.224524 [ 3445 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:28.304977 [ 3412 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:28.363188 [ 3409 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:28.712358 [ 3399 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:28.721015 [ 3416 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:28.724186 [ 3403 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:29.225646 [ 3401 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:29.306597 [ 3439 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:29.365326 [ 3386 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:29.713845 [ 3367 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:29.722417 [ 3374 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:29.725539 [ 3376 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:30.227156 [ 3385 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:30.308365 [ 3360 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:30.367000 [ 3366 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:30.715283 [ 3364 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:30.723569 [ 3382 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:30.726855 [ 3351 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:31.228561 [ 3354 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:31.309420 [ 3347 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:31.368333 [ 3342 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:31.716294 [ 3330 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:31.724715 [ 3323 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:31.728423 [ 3305 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:32.229983 [ 3311 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:32.258930 [ 3657 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {0b0d3576-e33b-4f3a-9561-33ccaccd3fd9::202510_1_264_53}: 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 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) @ 0x0000000039c89948 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000003999bfb7 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 @ 0x00000000399942f0 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000039d15c04 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&) @ 0x0000000039d20399 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) @ 0x0000000039d1c606 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000396308a4 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x00000000396235dd 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000003963b3e0 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x00000000396504a0 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3c455d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 28. ? @ 0x00007f100c857ac3 29. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:32.310394 [ 3293 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:32.369522 [ 3299 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:32.441962 [ 3653 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {c84fffe3-f7b9-426e-917b-60cee886efa2::202510_1_273_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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000002009b98d 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x000000002009675f 5. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:129: CurrentMemoryTracker::injectFault() @ 0x000000001ff7d1df 6. ./build_docker/./src/Common/ThreadFuzzer.cpp:270: DB::ThreadFuzzer::maybeInjectMemoryLimitException() @ 0x000000002011909f 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:151: DB::MergePlainMergeTreeTask::finish() @ 0x000000003a3c7732 8. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3c4534 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:32.717181 [ 3287 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:32.725950 [ 3312 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:32.729706 [ 3325 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:33.231298 [ 3278 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:33.311208 [ 3276 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:33.370486 [ 3261 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:33.718403 [ 3262 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:33.727098 [ 3267 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:33.731033 [ 3260 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:34.232497 [ 3253 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:34.312222 [ 3249 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:34.371936 [ 3259 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:34.719546 [ 3239 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:34.728387 [ 3234 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:34.732425 [ 3235 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:35.233648 [ 3245 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:35.313168 [ 3237 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:35.373122 [ 3225 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:35.721039 [ 3211 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:35.729763 [ 3210 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:35.733586 [ 3190 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:36.235099 [ 3198 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:36.314431 [ 3205 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:36.374549 [ 3219 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:36.722650 [ 3185 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:36.731180 [ 3187 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:36.735014 [ 3172 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:37.236664 [ 3165 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:37.315635 [ 3175 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:37.376276 [ 3167 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:37.724040 [ 3153 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:37.732385 [ 3160 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:37.736618 [ 3151 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:38.238176 [ 3150 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:38.316984 [ 3142 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:38.376682 [ 32712 ] {7c97df86-53b3-4198-8e89-3d8a2845a20a} 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.10542.altinitytest (altinity build)) (from [::1]:35228) (comment: 01396_inactive_replica_cleanup_nodes_zookeeper.sh) (in query: SELECT sum(toUInt32(extract(message, 'Removed (\d+) old log entries'))) FROM system.text_log WHERE event_date >= yesterday() AND logger_name LIKE '%' || 'test_uttb102q' || '%r1%(ReplicatedMergeTreeCleanupThread)%' AND message LIKE '%Removed % old log entries%'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 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) @ 0x0000000039c89948 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000003999bfb7 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 @ 0x00000000399942f0 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039d45fb0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003bfd663a 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c083c53 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003bfe2b53 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d3c440 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf89b85 18. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 19. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 23. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 24. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 26. ? @ 0x00007f100c857ac3 27. ? @ 0x00007f100c8e9850 2025.10.23 23:58:38.377735 [ 3126 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:38.386334 [ 32712 ] {7c97df86-53b3-4198-8e89-3d8a2845a20a} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039c11823 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039c06862 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039c05cd9 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) @ 0x0000000039c89948 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:0: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000003999bfb7 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 @ 0x00000000399942f0 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039d45fb0 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003bfd663a 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c083c53 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003bfe2b53 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d3c440 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf89b85 18. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae7059e 19. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003aed722d 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003aea6166 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4223 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 23. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 24. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 26. ? @ 0x00007f100c857ac3 27. ? @ 0x00007f100c8e9850 2025.10.23 23:58:38.725432 [ 3118 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:38.733702 [ 3138 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:38.737957 [ 3115 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:39.239603 [ 3131 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:39.317871 [ 3159 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:39.378924 [ 3113 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:39.726389 [ 3122 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:39.734605 [ 3091 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:39.739346 [ 3099 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:40.241094 [ 3084 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:40.318967 [ 3079 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:40.469105 [ 3072 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:40.736234 [ 3058 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:40.727626 [ 3081 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:40.789058 [ 3064 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:40.902483 [ 3645 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {eca3dc2f-d725-4477-8dd8-6130f79f34c3::202510_1_85_36_18}: 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000002009b98d 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x000000002009675f 5. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:129: CurrentMemoryTracker::injectFault() @ 0x000000001ff7d1df 6. ./build_docker/./src/Common/ThreadFuzzer.cpp:270: DB::ThreadFuzzer::maybeInjectMemoryLimitException() @ 0x000000002011909f 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:151: DB::MergePlainMergeTreeTask::finish() @ 0x000000003a3c7732 8. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3c4534 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:41.242346 [ 3055 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:41.320458 [ 3073 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:41.470429 [ 3396 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:41.737653 [ 3433 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:41.749822 [ 3322 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:41.790794 [ 3265 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:42.243652 [ 3329 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:42.321730 [ 3564 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:42.472488 [ 3201 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:42.738710 [ 3562 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:42.750996 [ 3111 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:42.792376 [ 3542 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:43.245260 [ 3540 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:43.323110 [ 3535 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:43.473912 [ 3565 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:43.739967 [ 3207 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:43.752215 [ 3531 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:43.793409 [ 3526 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:44.246753 [ 3521 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:44.324356 [ 3523 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:44.475454 [ 3505 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:44.741308 [ 3507 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:44.753617 [ 3508 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:44.794781 [ 3524 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:45.248365 [ 3506 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:45.325539 [ 3488 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:45.477193 [ 3495 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:45.742533 [ 3493 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:45.755350 [ 3476 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:45.796475 [ 3486 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:46.249544 [ 3473 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:46.326714 [ 3485 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:46.480573 [ 3461 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:46.743912 [ 3459 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:46.756868 [ 3457 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:46.797912 [ 3452 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:47.251021 [ 3466 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:47.328208 [ 3458 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:47.482222 [ 3449 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:47.745199 [ 3423 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:47.758775 [ 3434 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:47.799168 [ 3533 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:48.252316 [ 3424 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:48.329160 [ 3409 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:48.483892 [ 3393 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:48.746546 [ 3474 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:48.760212 [ 3387 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:48.800453 [ 3390 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:49.253465 [ 3377 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:49.330411 [ 3378 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:49.485240 [ 3367 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:49.748184 [ 3381 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:49.761187 [ 3402 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:49.801781 [ 3368 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:50.254588 [ 3364 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:50.331916 [ 3351 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:50.486556 [ 3336 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:50.749245 [ 3365 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:50.762022 [ 3357 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:50.803207 [ 3354 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:51.281368 [ 3315 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:51.333602 [ 3334 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:51.479351 [ 3361 ] {} test_uttb102q.r2 (2fc51855-9381-49a2-b82b-db5c5132e917): Will mimic 1r1 2025.10.23 23:58:51.488117 [ 3333 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:51.750449 [ 3353 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:51.763140 [ 3313 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:51.804676 [ 3327 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:52.282787 [ 3331 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:52.334763 [ 3308 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:52.489224 [ 3299 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:52.751583 [ 3325 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:52.768887 [ 3285 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:52.806122 [ 3292 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:53.284497 [ 3276 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:53.336041 [ 3261 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:53.490244 [ 3268 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:53.753126 [ 3264 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:53.770013 [ 3252 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:53.807425 [ 3255 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:54.058048 [ 4841 ] {7e4e70e7-6644-4e3d-b72e-4ae5e2ecbad6} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:43142) (comment: 01396_inactive_replica_cleanup_nodes_zookeeper.sh) (in query: DROP DATABASE IF EXISTS test_uttb102q ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:58:54.063973 [ 4841 ] {7e4e70e7-6644-4e3d-b72e-4ae5e2ecbad6} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:54.233240 [ 32712 ] {2bb6c474-c1f5-4a93-8588-2ba3bf56a533} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:43158) (comment: 01396_inactive_replica_cleanup_nodes_zookeeper.sh) (in query: DROP DATABASE IF EXISTS test_uttb102q ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 2025.10.23 23:58:54.238023 [ 32712 ] {2bb6c474-c1f5-4a93-8588-2ba3bf56a533} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083d4a64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000339ab19a 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034948517 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000003493a28d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034937401 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034936993 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 19. ? @ 0x00007f100c857ac3 20. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:54.285840 [ 3242 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:54.337253 [ 3240 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:54.491400 [ 3228 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:54.754474 [ 3226 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:54.771038 [ 3232 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:54.809053 [ 3235 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:55.286971 [ 3225 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:55.338211 [ 3222 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:55.492995 [ 3206 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:55.755473 [ 3209 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:55.772043 [ 3200 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:55.810173 [ 3198 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:56.288350 [ 3179 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:56.339322 [ 3185 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:56.494189 [ 3173 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:56.834461 [ 3166 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:56.834573 [ 3178 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:56.835293 [ 3166 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:57.289526 [ 3517 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:57.340533 [ 3150 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:57.495334 [ 3163 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:57.835473 [ 3121 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:57.836123 [ 3142 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:57.836196 [ 3149 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:58.290845 [ 3140 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:58.341744 [ 3120 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:58.496805 [ 3112 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:58.836901 [ 3391 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:58.837246 [ 3319 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:58.837311 [ 3223 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:59.292240 [ 3105 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:59.342776 [ 3104 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:59.498449 [ 3102 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:59.838188 [ 3095 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:59.838245 [ 3093 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:59.838250 [ 3092 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:59:00.293237 [ 3085 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:59:00.344010 [ 3084 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:59:00.499666 [ 3082 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:59:00.839315 [ 3460 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:59:00.839606 [ 3467 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:59:00.839669 [ 3461 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:59:01.294574 [ 3322 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:59:01.345328 [ 3321 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:59:01.500896 [ 3314 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:59:01.840265 [ 3308 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:59:01.840840 [ 3307 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:59:01.841017 [ 3304 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:59:02.295822 [ 3260 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:59:02.346534 [ 3255 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:59:02.502288 [ 3235 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:59:02.841177 [ 3177 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:59:02.841634 [ 3180 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:59:02.841760 [ 3177 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:59:03.296862 [ 3061 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:59:03.347452 [ 3391 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:59:03.503599 [ 3109 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:59:03.842271 [ 3072 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:59:03.842614 [ 3068 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:59:03.842613 [ 3075 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:59:04.298136 [ 3525 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:59:04.348877 [ 3518 ] {} test_u4vuh4wv.rmt1 (e3b696d2-d17c-4942-9b33-53deff826520): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:59:04.504916 [ 3564 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:59:04.843405 [ 3507 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000003889e6e8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa6f5f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:59:04.844384 [ 3487 ] {} test_u4vuh4wv.rmt2 (799f029e-df4f-4a8f-881a-e825954b0364): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_u4vuh4wv/02438/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:59:04.844390 [ 3484 ] {} test_11_db.`.inner_id.460981ca-ba7e-4f1f-9e3f-cf5463cc5802` (824fc315-cbc3-4b43-87ca-6dd1b9c23075): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/824fc315-cbc3-4b43-87ca-6dd1b9c23075/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f100c857ac3 13. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:59:11.012288 [ 3649 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {26a86919-b755-436d-800b-c04857d425d1::202510_1_275_123}: 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000002009b98d 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x000000002009675f 5. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:129: CurrentMemoryTracker::injectFault() @ 0x000000001ff7d1df 6. ./build_docker/./src/Common/ThreadFuzzer.cpp:270: DB::ThreadFuzzer::maybeInjectMemoryLimitException() @ 0x000000002011909f 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:151: DB::MergePlainMergeTreeTask::finish() @ 0x000000003a3c7732 8. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3c4534 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000396abc3e 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000396ada08 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000396b4d1f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d7593 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e9bc6 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e997f 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 17. ? @ 0x00007f100c857ac3 18. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.24 00:00:05.329274 [ 35663 ] {d2e778bc-3718-4d90-8156-165cb714dd82} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 60.16443668 seconds, maximum: 60. (TIMEOUT_EXCEEDED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44444) (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x00000000322cd7ed 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x00000000322cb868 5. ./build_docker/./src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000003502621c 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 9. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 11. ? @ 0x00007f100c857ac3 12. ? @ 0x00007f100c8e9850 2025.10.24 00:00:05.331748 [ 35663 ] {d2e778bc-3718-4d90-8156-165cb714dd82} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 60.16443668 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x00000000322cd7ed 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x00000000322cb868 5. ./build_docker/./src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000003502621c 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003aea44ce 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3d8a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 9. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 11. ? @ 0x00007f100c857ac3 12. ? @ 0x00007f100c8e9850 2025.10.24 00:00:07.143865 [ 35663 ] {f0c7b1ad-0297-4eda-9e36-6d5f1bbbad27} executeQuery: Code: 521. DB::ErrnoException: Cannot rename /var/lib/clickhouse/metadata/test.sql.tmp to /var/lib/clickhouse/metadata/test.sql because the second path already exists: , errno: 17, strerror: File exists. (ATOMIC_RENAME_FAIL) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:45614) (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::ErrnoException::ErrnoException(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x00000000329b97b2 4. ./build_docker/./src/Common/atomicRename.cpp:92: DB::renameat2(String const&, String const&, int) @ 0x00000000329b90c8 5. ./build_docker/./src/Common/atomicRename.cpp:213: DB::renameNoReplace(String const&, String const&) @ 0x00000000329b8024 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000034894382 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 10. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 11. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 2025.10.24 00:00:07.147280 [ 35663 ] {f0c7b1ad-0297-4eda-9e36-6d5f1bbbad27} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: DB::ErrnoException::ErrnoException(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x00000000329b97b2 4. ./build_docker/./src/Common/atomicRename.cpp:92: DB::renameat2(String const&, String const&, int) @ 0x00000000329b90c8 5. ./build_docker/./src/Common/atomicRename.cpp:213: DB::renameNoReplace(String const&, String const&) @ 0x00000000329b8024 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000034894382 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348f6f46 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358b83d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358c5c37 10. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003aa28091 11. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aa344a8 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac5aa01 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000004062d820 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x000000004062e760 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000405104f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004050cece 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000040509d91 18. ? @ 0x00007f100c857ac3 19. ? @ 0x00007f100c8e9850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.24 00:00:22.070735 [ 2898 ] {} Application: Closed all listening sockets. Waiting for 19 outstanding connections. 2025.10.24 00:00:26.977469 [ 2898 ] {} Application: Closed connections. But 19 remain. Tip: To increase wait time add to config: 60 2025.10.24 00:00:26.978157 [ 2898 ] {} Application: Will shutdown forcefully. 2025.10.24 00:00:29.793544 [ 35710 ] {} Context: Server was built with memory sanitizer. It will work slowly. 2025.10.24 00:00:29.816748 [ 35710 ] {} Context: Server logging level is set to 'test' and performance is degraded. This cannot be used in production. 2025.10.24 00:00:29.820518 [ 35710 ] {} 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.24 00:00:29.821910 [ 35710 ] {} 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.24 00:00:40.787437 [ 35710 ] {} KeeperServer: Got 1000000000000000 value for setting 'reserved_log_items' which is bigger than int32_t max value, lowering value to 2147483647. 2025.10.24 00:00:40.796459 [ 35710 ] {} RaftInstance: invalid election timeout lower bound detected, adjusted to 0 2025.10.24 00:00:40.796528 [ 35710 ] {} RaftInstance: invalid election timeout upper bound detected, adjusted to 0 2025.10.24 00:00:40.848044 [ 36353 ] {} RaftInstance: Election timeout, initiate leader election 2025.10.24 00:00:43.427661 [ 36485 ] {} system.metric_log (959c1387-6a29-41af-9a70-593d11e44aac): Removing temporary directory /var/lib/clickhouse/store/959/959c1387-6a29-41af-9a70-593d11e44aac/tmp_insert_202510_181_181_0/ 2025.10.24 00:00:45.155605 [ 35710 ] {} 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.24 00:00:45.887138 [ 35710 ] {} loadMetadata: Removing temporary file /var/lib/clickhouse/metadata/test.sql.tmp 2025.10.24 00:00:46.282320 [ 35710 ] {} TablesLoader: Tables test_15.test_dictionary3, test_15.test_dictionary0 depend on test_db.table_01, but seems like that does not exist. Will ignore it and try to load existing tables 2025.10.24 00:00:46.282669 [ 35710 ] {} TablesLoader: Tables test_3_1.zjoin depend on test_3_1.ydict1, but seems like that does not exist. Will ignore it and try to load existing tables 2025.10.24 00:00:46.283375 [ 35710 ] {} TablesLoader: Tables test_1.dist_01270 depend on default.key, but seems like that does not exist. Will ignore it and try to load existing tables 2025.10.24 00:00:46.283516 [ 35710 ] {} TablesLoader: Tables test_01103.t2_distr, test_01103.t1_distr depend on default.id, but seems like that does not exist. Will ignore it and try to load existing tables 2025.10.24 00:00:46.283620 [ 35710 ] {} TablesLoader: Tables test_3.dist_01247 depend on default.number, but seems like that does not exist. Will ignore it and try to load existing tables 2025.10.24 00:00:46.787989 [ 36535 ] {} DDLWorker(test_11_db): Replica seems to be lost: our_log_ptr=5, max_log_ptr=5, local_digest=9946128224941777605, zk_digest=7366927731166764538 2025.10.24 00:00:46.789986 [ 36535 ] {} DatabaseReplicated (test_11_db): Will recover replica with staled log pointer 5 from log pointer 5 2025.10.24 00:00:46.959643 [ 35776 ] {} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/StorageBuffer.cpp:0: DB::StorageBuffer::flushAllBuffers(bool) @ 0x0000000038ddb12c 8. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x0000000038de8318 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038dec4ff 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 15. ? @ 0x00007f8f99ae1ac3 16. ? @ 0x00007f8f99b73850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.24 00:00:47.767997 [ 35719 ] {8184e111-67f6-4dbb-b849-440a88708e38} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:41162) (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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f8f99ae1ac3 13. ? @ 0x00007f8f99b73850 2025.10.24 00:00:47.769462 [ 35719 ] {8184e111-67f6-4dbb-b849-440a88708e38} 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) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003aea818c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003aea4135 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003aea3c88 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aee411d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f8f99ae1ac3 13. ? @ 0x00007f8f99b73850 2025.10.24 00:01:06.822622 [ 35974 ] {} test_1.wrong_metadata_compact (eb663c70-8219-4e5a-a7c4-0d667ad8529e): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_1/tables/wrong_metadata_compact/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f8f99ae1ac3 13. ? @ 0x00007f8f99b73850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.24 00:01:06.822695 [ 35967 ] {} test_1.wrong_metadata (d97878fe-0e0d-4888-977a-0183d4d3b9ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /test/test_1/tables/wrong_metadata/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f8f99ae1ac3 13. ? @ 0x00007f8f99b73850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.24 00:01:06.822650 [ 35970 ] {} test_1.quorum1 (c0167c44-881d-4748-9492-36875b5d02d0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/test_00732/quorum2/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083c110a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386ea072 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000388abf81 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038aa701f 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x000000003199f3f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319aa713 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319ac3af 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202d03fd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202e2944 12. ? @ 0x00007f8f99ae1ac3 13. ? @ 0x00007f8f99b73850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.24 00:01:07.731825 [ 35710 ] {} virtual void DB::StorageBuffer::flushAndPrepareForShutdown(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403ed4e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000020032213 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000837fb9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ea5f4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202dab29 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202da3aa 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303ee5fd 7. ./build_docker/./src/Storages/StorageBuffer.cpp:0: DB::StorageBuffer::flushAllBuffers(bool) @ 0x0000000038ddb12c 8. ./build_docker/./src/Storages/StorageBuffer.cpp:0: DB::StorageBuffer::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x0000000038dda6c8 9. ./contrib/llvm-project/libcxx/include/vector:438: DB::StorageBuffer::flushAndPrepareForShutdown() @ 0x0000000038dd9ed3 10. ./contrib/llvm-project/libcxx/include/__tree:189: DB::DatabaseWithOwnTablesBase::shutdown() @ 0x0000000032af5d23 11. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:184: DB::DatabaseOnDisk::shutdown() @ 0x000000003294d62a 12. ./contrib/llvm-project/libcxx/include/__tree:189: DB::DatabaseCatalog::shutdownImpl() @ 0x000000003399aa2f 13. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:869: DB::DatabaseCatalog::shutdown() @ 0x00000000339b2c6f 14. ./build_docker/./src/Interpreters/Context.cpp:624: DB::ContextSharedPart::shutdown() @ 0x00000000337cf920 15. ./build_docker/./src/Interpreters/Context.cpp:4783: DB::Context::shutdown() @ 0x00000000337a1a9f 16. ./build_docker/./programs/server/Server.cpp:936: DB::Server::main(std::vector> const&)::$_2::operator()() const @ 0x0000000020638eb6 17. ./base/base/../base/scope_guard.h:0: DB::Server::main(std::vector> const&) @ 0x00000000205f4680 18. ./build_docker/./base/poco/Util/src/Application.cpp:0: Poco::Util::Application::run() @ 0x00000000406a74bf 19. ./build_docker/./programs/server/Server.cpp:397: DB::Server::run() @ 0x00000000205b6e8b 20. ./build_docker/./base/poco/Util/src/ServerApplication.cpp:132: Poco::Util::ServerApplication::run(int, char**) @ 0x00000000406ee7a0 21. ./build_docker/./programs/server/Server.cpp:0: mainEntryClickHouseServer(int, char**) @ 0x00000000205af969 22. ./build_docker/./programs/main.cpp:0: main @ 0x000000000836cc4a 23. ? @ 0x00007f8f99a76d90 24. ? @ 0x00007f8f99a76e40 25. _start @ 0x00000000082e002e (version 24.8.14.10542.altinitytest (altinity build))